2025.04.02 09:40:08.128222 [ 435 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.04.02 09:40:09.840640 [ 435 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.04.02 09:40:09.842245 [ 435 ] {} KeeperLogStore: Removing all changelogs 2025.04.02 09:40:09.843484 [ 435 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.04.02 09:40:09.859086 [ 435 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.04.02 09:40:09.859164 [ 435 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.04.02 09:40:09.911822 [ 1026 ] {} RaftInstance: Election timeout, initiate leader election 2025.04.02 09:40:09.968634 [ 435 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.04.02 09:40:09.968708 [ 435 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.04.02 09:40:10.009738 [ 435 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.04.02 09:40:10.011632 [ 435 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.04.02 09:40:20.654174 [ 1430 ] {3fd45651-d061-4244-8202-db9847a61ff0} executeQuery: Code: 182. DB::Exception: Table expression test_er4kfapp.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48368) (comment: 02575_merge_prewhere_ephemeral.sql) (in query: SELECT * FROM m PREWHERE f = 1 ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000007c838ac 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:228: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ae43 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ac7c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ac7c 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:320: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000018b38531 8. ./build_docker/./src/Planner/Planner.cpp:1494: DB::Planner::buildPlanForQueryNode() @ 0x000000001999c88b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:20.657814 [ 1430 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_er4kfapp.m AS __table1 does not support column __table1.f in PREWHERE. In query SELECT * FROM m PREWHERE f = 1 ORDER BY a ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000007c838ac 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:228: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ae43 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ac7c 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b3ac7c 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:320: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000018b38531 8. ./build_docker/./src/Planner/Planner.cpp:1494: DB::Planner::buildPlanForQueryNode() @ 0x000000001999c88b 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:20.759849 [ 1432 ] {f3cdf563-0298-4994-bc1a-7d4674ed3d3c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48376) (comment: 02707_skip_index_with_in.sql) (in query: EXPLAIN SELECT count() FROM t_skip_index_in WHERE c IN (SELECT throwIf(1)) SETTINGS use_skip_indexes = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/PreparedSets.cpp:254: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000019ab3104 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:399: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001bd2aad8 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:361: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001bd2a875 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:208: bool std::__function::__policy_invoker::__call_impl, DB::Block const&, unsigned long)::$_0, bool (DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&)>>(std::__function::__policy_storage const*, DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001bd32c32 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001bd44d72 23. ./src/Storages/MergeTree/RPNBuilder.h:202: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x000000001bd292ec 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x000000001bd32444 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1635: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001cbddbf4 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001cbdc7e3 27. ./src/Processors/QueryPlan/SourceStepWithFilter.h:65: DB::SourceStepWithFilter::applyFilters() @ 0x000000001ccc9146 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001ccc8f60 29. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:118: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001cca6b28 30. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:471: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001cbb3e52 31. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:471: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000195010fa 2025.04.02 09:40:20.765576 [ 1432 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/PreparedSets.cpp:254: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000019ab3104 19. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:399: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x000000001bd2aad8 20. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:361: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001bd2a875 21. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:208: bool std::__function::__policy_invoker::__call_impl, DB::Block const&, unsigned long)::$_0, bool (DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&)>>(std::__function::__policy_storage const*, DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x000000001bd32c32 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001bd44d72 23. ./src/Storages/MergeTree/RPNBuilder.h:202: DB::MergeTreeIndexConditionBloomFilter::MergeTreeIndexConditionBloomFilter(DB::ActionsDAG const*, std::shared_ptr, DB::Block const&, unsigned long) @ 0x000000001bd292ec 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x000000001bd32444 25. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1635: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001cbddbf4 26. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1672: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001cbdc7e3 27. ./src/Processors/QueryPlan/SourceStepWithFilter.h:65: DB::SourceStepWithFilter::applyFilters() @ 0x000000001ccc9146 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:55: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001ccc8f60 29. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:118: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001cca6b28 30. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:471: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001cbb3e52 31. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:471: DB::InterpreterExplainQuery::executeImpl() @ 0x00000000195010fa 2025.04.02 09:40:21.047095 [ 1380 ] {a4de8bb3-1ef8-4e96-b41f-f5435caee06c} executeQuery: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48370) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 to value2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/AlterCommands.cpp:1589: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b21171c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.049317 [ 1380 ] {} TCPHandler: Code: 15. DB::Exception: Cannot rename to `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/AlterCommands.cpp:1589: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b21171c 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.158249 [ 1380 ] {35375dd0-d691-4d42-9d65-06b83d067384} executeQuery: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48370) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN value3 TO r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b210ddb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.160758 [ 1380 ] {} TCPHandler: Code: 36. DB::Exception: Cannot rename column '`value3`' to two different names in a single ALTER query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/AlterCommands.cpp:1563: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b210ddb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.269042 [ 1380 ] {1f2e3557-d7f1-48c1-842a-7561fc452f6d} executeQuery: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48370) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value3 TO r1, RENAME COLUMN r1 TO value1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/AlterCommands.cpp:1561: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b210d03 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.270557 [ 1380 ] {} TCPHandler: Code: 48. DB::Exception: Transitive renames in a single ALTER query are not allowed (don't make sense). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/AlterCommands.cpp:1561: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b210d03 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.509224 [ 1380 ] {a43cca41-1008-4266-9372-0890ef1ebd6c} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48370) (comment: 01213_alter_rename_column.sql) (in query: ALTER TABLE table_for_rename RENAME COLUMN value100 to renamed_value100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Storages/AlterCommands.cpp:1583: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b211b09 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.511222 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value100` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Storages/AlterCommands.cpp:1583: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000001b211b09 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a571d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.620677 [ 1432 ] {4ef66a9c-e33d-4042-ac7b-0f6be9d03869} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46890) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.622460 [ 1432 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.668802 [ 1429 ] {84b38975-435c-417d-84b7-c88985c31d7c} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:21.671670 [ 1429 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:21.854941 [ 1424 ] {35ca0d11-8974-47a8-8610-fddfe8e817ea} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46892) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.858872 [ 1424 ] {} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:21.865038 [ 1429 ] {ee5f167e-fd5e-48e3-9564-4ce530b45f08} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.1', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:21.871102 [ 1429 ] {} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.244546 [ 1435 ] {f5bd9018-51b4-477f-b54d-cdd8ecd610ea} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39254) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.246114 [ 1435 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.253410 [ 1429 ] {959b4f56-2964-4043-9157-98466b4b8f83} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_rows_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.256575 [ 1429 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 1.00, current rows: 100.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:631: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000001cc7c2c6 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:551: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000001cc7b0e4 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:430: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cc79ad6 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.357162 [ 1435 ] {b9e2af1b-0a06-4b50-9a1c-56213c659a7f} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39270) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers` AS `__table1` LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.359617 [ 1435 ] {} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.366186 [ 1429 ] {5a1b9347-1d53-43df-89cd-5e71045a6583} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM remote('127.0.0.2', system.numbers) LIMIT 100) SETTINGS max_bytes_to_read_leaf=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.373636 [ 1429 ] {} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 1.00 B, current bytes: 800.00 B: While executing NumbersRange. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.581644 [ 1434 ] {9d01c59c-25d2-4927-8fcd-5319e22341f0} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34906) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.585331 [ 1434 ] {9d01c59c-25d2-4927-8fcd-5319e22341f0} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.615486 [ 1380 ] {d77ed69f-779a-485f-9960-b206f755a6d4} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34910) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.619246 [ 1380 ] {d77ed69f-779a-485f-9960-b206f755a6d4} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.656351 [ 1380 ] {b56134eb-ee75-46ee-a30f-d8b223cbaacb} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34912) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.660723 [ 1380 ] {b56134eb-ee75-46ee-a30f-d8b223cbaacb} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.694119 [ 1424 ] {4aef04ba-86de-4e80-a092-bc0c1081edf5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34920) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.696068 [ 1424 ] {4aef04ba-86de-4e80-a092-bc0c1081edf5} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.724507 [ 1424 ] {c462d539-7380-49a8-9db2-098ded66e070} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34930) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.726604 [ 1424 ] {c462d539-7380-49a8-9db2-098ded66e070} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.766076 [ 1435 ] {2a79d6ce-0c20-4ada-8ce4-6f6b38725c02} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34946) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.771085 [ 1435 ] {2a79d6ce-0c20-4ada-8ce4-6f6b38725c02} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.796084 [ 1424 ] {ae874119-471c-4546-b2e9-63d379f469c5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34954) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.798057 [ 1424 ] {ae874119-471c-4546-b2e9-63d379f469c5} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.829480 [ 1432 ] {fc09031e-5ffa-4602-a624-7dd3d255ca2d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34964) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.833224 [ 1432 ] {fc09031e-5ffa-4602-a624-7dd3d255ca2d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.874757 [ 1380 ] {4fca4777-3710-4641-8da1-934c395406df} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34978) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.877215 [ 1380 ] {4fca4777-3710-4641-8da1-934c395406df} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.911025 [ 1380 ] {97fb97f2-4773-4a00-8c9b-2ceea50c43c8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34984) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.913569 [ 1380 ] {97fb97f2-4773-4a00-8c9b-2ceea50c43c8} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.918415 [ 1424 ] {b76a2720-73eb-4b28-8303-3d36a7591d14} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39310) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_2r2a8cem`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.918791 [ 1535 ] {d191a0f0-3d53-4548-a1b0-d7ed5c73078b} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46906) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_2r2a8cem`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.920006 [ 1424 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.921297 [ 1535 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.928566 [ 1429 ] {b3188527-d63b-4951-8e45-cf610315f0e4} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_rows_to_read_leaf = 40000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.933222 [ 1429 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read_leaf' setting) exceeded, max rows: 40.00 thousand, current rows: 50.00 thousand. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x00000000183e371d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:316: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001cbc5f08 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2082: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbe4805 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80983 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:22.941043 [ 1380 ] {e31703da-f275-487e-a901-e1ccd70de0c1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:34994) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.944044 [ 1380 ] {e31703da-f275-487e-a901-e1ccd70de0c1} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:22.977967 [ 1380 ] {af5041eb-9a9b-4a22-9859-977404dd71cf} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35006) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:22.981125 [ 1380 ] {af5041eb-9a9b-4a22-9859-977404dd71cf} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.000585 [ 1431 ] {ff000dfa-88dd-4e25-8aaa-12e90f87a492} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:46912) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_2r2a8cem`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.002518 [ 1431 ] {} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.007353 [ 1430 ] {59ce9b09-55f4-4cc4-9a8d-e03b48700ab5} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39312) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT `__table1`.`date` AS `date` FROM `test_2r2a8cem`.`test_local` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.009969 [ 1430 ] {} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.010078 [ 1380 ] {dbf1daee-109d-495e-a3a3-423cae832582} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:35014) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.012522 [ 1380 ] {dbf1daee-109d-495e-a3a3-423cae832582} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.018197 [ 1429 ] {646e52a6-c5bb-4f4a-a350-566cb467013c} executeQuery: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_bytes_to_read_leaf = 40000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:23.020344 [ 1429 ] {} TCPHandler: Code: 307. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Limit for rows or bytes to read on leaf node exceeded, max bytes: 39.06 KiB, current bytes: 97.66 KiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:117: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abdab 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 13. __tsan_thread_start_func @ 0x0000000007b08428 14. ? @ 0x00007fd7c201fac3 15. ? @ 0x00007fd7c20b1850 : While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:104: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000010476a4b 3. ./build_docker/./src/Client/Connection.cpp:1426: DB::Connection::receiveException() const @ 0x000000001c271c3e 4. ./build_docker/./src/Client/Connection.cpp:1255: DB::Connection::receivePacket() @ 0x000000001c27bd2e 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001c2dc37e 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:40:23.045020 [ 1380 ] {eef02a80-0abd-44a6-9247-baa71411781e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44488) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.047371 [ 1380 ] {eef02a80-0abd-44a6-9247-baa71411781e} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.074186 [ 1380 ] {97eba912-e680-4347-b658-2bd98e14ea35} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44490) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.076820 [ 1380 ] {97eba912-e680-4347-b658-2bd98e14ea35} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.103885 [ 1380 ] {acee3be6-4cab-434d-b6a3-d590fb38afea} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44502) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.106294 [ 1380 ] {acee3be6-4cab-434d-b6a3-d590fb38afea} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.129262 [ 1435 ] {05941131-8683-4a40-a498-8b267e2b116a} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44510) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.131257 [ 1435 ] {05941131-8683-4a40-a498-8b267e2b116a} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.155067 [ 1433 ] {9b632592-1c23-4bda-9690-f215cc1edaed} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44516) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format XML settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.156476 [ 1433 ] {9b632592-1c23-4bda-9690-f215cc1edaed} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.173380 [ 1429 ] {15553033-f352-47f7-9e71-1734712528c9} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 60.00 thousand, current rows: 100.00 thousand: While executing Remote. (TOO_MANY_ROWS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_rows_to_read = 60000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abd83 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.178447 [ 1429 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 60.00 thousand, current rows: 100.00 thousand: While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000183e3c6c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e344c 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abd83 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.187979 [ 1434 ] {20281a93-1a23-4420-aabe-e4fefe3afdc8} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44522) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.192102 [ 1434 ] {20281a93-1a23-4420-aabe-e4fefe3afdc8} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:23.212639 [ 441 ] {f6292924-ba99-4530-8367-f17ebb817715} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT hasSubstr([1], ['a']). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48474) (comment: 00555_hasSubstr.sql) (in query: select hasSubstr([1], ['a']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d00f6 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe47dbe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:40:23.214794 [ 441 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT hasSubstr([1], ['a']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d00f6 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe47dbe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:40:23.312377 [ 1432 ] {0b2e28cf-9a62-4181-a559-f015ce4fd22c} executeQuery: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48484) (comment: 03149_analyzer_window_redefinition.sql) (in query: SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid), w AS(ORDER BY name);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x0000000008483466 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5530: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94e76 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.314261 [ 1432 ] {} TCPHandler: Code: 36. DB::Exception: Window 'w' is already defined. In scope SELECT count(*) OVER w FROM users WINDOW w AS (ORDER BY uid ASC), w AS (ORDER BY name ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x0000000008483466 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5530: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94e76 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.371716 [ 441 ] {644063a1-7d47-4ee9-ab55-c38999811677} executeQuery: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasSubstr([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48474) (comment: 00555_hasSubstr.sql) (in query: select hasSubstr([[1, 2], [3, 4]], ['a', 'c']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c10 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d00f6 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe47dbe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:40:23.373759 [ 441 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Array(UInt8), String because some of them are Array and some of them are not: In scope SELECT hasSubstr([[1, 2], [3, 4]], ['a', 'c']). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:355: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c10 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:357: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d00f6 7. DB::FunctionArrayHasAllAny::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe47dbe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:40:23.426082 [ 1429 ] {8b11e9e6-bce3-42b6-8d38-f06a2e0745d0} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 97.66 KiB, current bytes: 195.31 KiB: While executing Remote. (TOO_MANY_BYTES) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48426) (comment: 01455_shard_leaf_max_rows_bytes_to_read.sql) (in query: SELECT count() FROM (SELECT * FROM test_distributed) SETTINGS max_bytes_to_read = 100000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abd83 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.429738 [ 1429 ] {} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 97.66 KiB, current bytes: 195.31 KiB: While executing Remote. (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x00000000183e3dac 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000183e3579 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x00000000183abd83 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:64: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532af2 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.868292 [ 1432 ] {3613e1ac-dcc7-470b-a8e9-5dbd0415ed9d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44534) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:23.871384 [ 1432 ] {3613e1ac-dcc7-470b-a8e9-5dbd0415ed9d} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:24.568062 [ 1429 ] {4e499532-e80b-412a-a438-b61f607c2a47} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44540) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:24.573509 [ 1429 ] {4e499532-e80b-412a-a438-b61f607c2a47} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:24.726037 [ 1652 ] {62922630-8f27-4601-a46c-46127f2204e8} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) . (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x00000000105a8d00 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c5eeefb 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:24.731192 [ 1433 ] {62922630-8f27-4601-a46c-46127f2204e8} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42252) (comment: 02685_bson2.sql) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7ðâQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion2SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&·ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID úFÚÓ“2qJavaEnableTitleGoodEventEventTimen$äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeǘãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchIDl!è–|¨@HJavaEnableTitleGoodEventEventTimeÃ)äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime}žãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID^WatchID²Ç=ÐŒWJavaEnableTitleGoodEventEventTime8*äQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeÝžãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID‹WatchIDéòˆE&LyJavaEnableTitleGoodEventEventTimeJîâQEventDate>CounterIDClientIPº‹I`RegionID'UserIDq—íJd8CounterClassOSUserAgentURL-http://holodilnik.ru/russia/05jul2013&model=0RefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID¬9URLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkIDŒd9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID%œlû©+kOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime'¡ãQAgeSexIncomeInterests¦:RobotnessRemoteIP9ê3NWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashŽ oâïòeCLID¦WatchID¹ãk=÷±pJavaEnableTitleGoodEventEventTimeÉ ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID ÎKs}¡ïCounterClassOSUserAgentURLHhttp://afisha.mail.ru/catalog/314/women.ru/ency=1&page3/?errovat-pinnikiRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryID0=URLRegionIDØResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqID:¤ìWëÂmOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeA¶ãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashý€ à#â\CLIDœWatchIDæ1þž oíCJavaEnableTitleGoodEventEventTimeµ0äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL>http://bonprix.ru/index.ru/cinema/art/0 986 424 233 ÑезонRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime¼£ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashX-h³ýX CLID˜WatchID»-ÞC_JavaEnableTitleGoodEventEventTime83äQEventDate>CounterIDClientIPÉ^{]RegionIDÅUserID&n%Št"6CounterClassOS'UserAgentURL:http://bonprix.ru/index.ru/cinema/art/A00387,3797); ru)&bLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID±ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID‰#(TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime ¦ãQAgeSexIncomeInterestsRobotnessRemoteIP…UWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashvÀvÍÀ‰ÇCLIDWatchIDìÒŒ\JavaEnableTitleGoodEventEventTime× äQEventDate>CounterIDClientIPgURegionIDåUserIDƒs—yyçófCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDØesRolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¶œTraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY’ãQAgeSexIncomeInterestsRobotnessRemoteIP€=kWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashh˜´9›DCLID^WatchIDÛ/E‚ÜJÛ{JavaEnableTitleGoodEventEventTimeÖ1ãQEventDate>CounterIDClientIP®Æz·RegionIDGUserID× ’•:6×ÝCounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID¯á9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZoneÿÿÿÿClientEventTimeîáSilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime‹ÏãQAgeSexIncomeInterestsRobotnessRemoteIP^DIÄWindowNameÿÿÿÿOpenerNameÿÿÿÿHistoryLengthÿÿÿÿBrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+‚Œ'ÕãûURLHashÍ|3úÐb.‹CLID$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x00000000105a8d00 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c5eeefb 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:24.734546 [ 1433 ] {} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: SilverlightVersion2: (at row 1) : While executing ParallelParsingBlockInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type>, StringRef&) @ 0x00000000105a8d00 4. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c5eeefb 5. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 6. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 7. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 9. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 10. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 11. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:24.785136 [ 1380 ] {7692b442-14ab-4b7e-974d-932823c75a37} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(number, 1) FROM numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2ec3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:24.788297 [ 1380 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2ec3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:24.941857 [ 1380 ] {b52ab3c6-0119-403e-b2b1-cd56151822b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008074266 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2f75 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:24.944603 [ 1380 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008074266 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2f75 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:25.045139 [ 1434 ] {f9c29363-ac10-409e-9255-cdae7b2f2e0e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44548) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:25.048192 [ 1434 ] {f9c29363-ac10-409e-9255-cdae7b2f2e0e} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:25.108104 [ 1380 ] {493704d7-c9b2-4adb-8dc5-138895340246} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 'b') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d3392 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.109896 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d3392 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.278881 [ 1380 ] {8aa6e5c8-6ab1-4a30-bff0-4e062a43e395} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.281960 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.295699 [ 1380 ] {a9bf919a-1b02-4f07-9d08-56562941791b} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.296812 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.495060 [ 1380 ] {6b897503-1fed-459d-9193-c9235e205040} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d352e 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.497208 [ 1380 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d352e 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.678390 [ 1380 ] {29c79730-a2a8-47f8-88fb-d6d742fab9fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008074266 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2f75 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:25.685164 [ 1435 ] {292149c6-2840-4eff-aca1-c934f9bd9c89} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44552) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:25.686969 [ 1380 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000008074266 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2f75 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:40:25.701466 [ 1380 ] {1e037af8-113d-4eb7-bc44-59584b4e8c3f} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 'a') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d3392 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.707118 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d3392 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.725553 [ 1380 ] {210a6796-f81c-49e9-a44a-0e95070daa58} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.729181 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.730652 [ 1435 ] {292149c6-2840-4eff-aca1-c934f9bd9c89} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:25.742363 [ 1380 ] {edcc752d-4a8d-4444-8a61-bc096727914e} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.746173 [ 1380 ] {} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000882a640 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d35b9 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.760152 [ 1380 ] {45d756a7-7d7b-473e-abe5-ab95b91d21f5} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42246) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d352e 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:25.763056 [ 1380 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000000e8d352e 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d2d1d 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:40:26.737165 [ 441 ] {1b0d4e52-7404-4906-8814-2201a851109e} executeQuery: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42322) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL STEP -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f71f4 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:26.739267 [ 441 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f71f4 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:26.851302 [ 441 ] {ad990bf0-ca51-465b-8adf-e8e682924908} executeQuery: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42322) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM 10 TO 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f72c3 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:26.853250 [ 441 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f72c3 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:26.993223 [ 441 ] {41e42392-1089-4dcf-8c71-cae1ed16b6c9} executeQuery: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42322) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a DESC WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f725d 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:26.995334 [ 441 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000199f725d 5. ./build_docker/./src/Planner/Planner.cpp:342: DB::Planner::buildPlanForQueryNode() @ 0x000000001999f222 6. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:27.125247 [ 441 ] {72356241-ca03-4d5a-aea3-73c53e3ab27a} executeQuery: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42322) (comment: 00995_order_by_with_fill.sql) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM -10 to 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:265: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb67708 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:27.127463 [ 441 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:265: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb67708 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:31.734070 [ 1432 ] {4e159ef2-ebde-4946-a39c-96e4af8145fe} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44566) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:31.738686 [ 1432 ] {4e159ef2-ebde-4946-a39c-96e4af8145fe} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:31.866733 [ 1435 ] {8bc4809e-6777-425e-81f3-b41d63a612a2} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44570) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:31.870266 [ 1435 ] {8bc4809e-6777-425e-81f3-b41d63a612a2} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:32.003827 [ 1435 ] {840f8057-25ea-4190-9ad9-add6bac7eebb} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44578) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:32.006923 [ 1435 ] {840f8057-25ea-4190-9ad9-add6bac7eebb} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:32.126450 [ 2177 ] {db22392a-d05a-4fd7-94a3-5470d3d02450} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44582) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:32.130719 [ 2177 ] {db22392a-d05a-4fd7-94a3-5470d3d02450} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:32.278624 [ 2179 ] {027f11ce-24a5-420e-807a-70cf79b1d561} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44586) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:32.281424 [ 2179 ] {027f11ce-24a5-420e-807a-70cf79b1d561} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:32.418567 [ 2179 ] {18108b2c-4485-45d6-86cf-5a64a17c5565} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44592) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852ceba 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:77: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c8afbee 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:32.423378 [ 2179 ] {18108b2c-4485-45d6-86cf-5a64a17c5565} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852ceba 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:77: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c8afbee 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:32.530651 [ 2179 ] {2b6cb7cd-d0bf-47d6-8c0e-5af099b6f085} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44594) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:32.535791 [ 2179 ] {2b6cb7cd-d0bf-47d6-8c0e-5af099b6f085} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:33.167324 [ 1435 ] {f42ec94f-d6b6-4168-8c3b-287048e53385} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:44606) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:33.236720 [ 1435 ] {f42ec94f-d6b6-4168-8c3b-287048e53385} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:33.831112 [ 2177 ] {8cb02f32-4f00-44b2-ac10-add020cc5e5d} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40952) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:33.912383 [ 2177 ] {8cb02f32-4f00-44b2-ac10-add020cc5e5d} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.141103 [ 2179 ] {69563e50-e682-4fd9-9c5d-1e6a28018bce} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40964) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:34.175002 [ 2179 ] {69563e50-e682-4fd9-9c5d-1e6a28018bce} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.779229 [ 2169 ] {777b0752-fcde-4dad-923c-5abde42beab5} ConnectionPoolWithFailover: There is no table `test_r8zyw55s`.`local_01099_b` on server: 127.0.0.2:9000 2025.04.02 09:40:34.781399 [ 2293 ] {777b0752-fcde-4dad-923c-5abde42beab5} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.781964 [ 2293 ] {777b0752-fcde-4dad-923c-5abde42beab5} ConnectionPoolWithFailover: Connection failed at try â„–2, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.782632 [ 2293 ] {777b0752-fcde-4dad-923c-5abde42beab5} ConnectionPoolWithFailover: Connection failed at try â„–3, reason: Code: 210. DB::NetException: Connection refused (127.0.0.3:1234). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.791213 [ 2168 ] {777b0752-fcde-4dad-923c-5abde42beab5} ConnectionPoolWithFailover: There is no table `test_r8zyw55s`.`local_01099_b` on server: 127.0.0.1:9000 2025.04.02 09:40:34.797286 [ 1433 ] {686244ac-2476-4957-a8ed-5bfa59fb0937} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40968) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:34.804777 [ 1433 ] {686244ac-2476-4957-a8ed-5bfa59fb0937} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:34.922896 [ 442 ] {777b0752-fcde-4dad-923c-5abde42beab5} StorageDistributed (distributed_01099_b): Cannot flush: Code: 279. DB::NetException: All connection tries failed. Log: There is no table `test_r8zyw55s`.`local_01099_b` on server: 127.0.0.2:9000 : While sending /var/lib/clickhouse/store/610/61084eeb-9099-4722-8f28-0c5daad1ba6a/shard1_replica2/2.bin. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./src/Common/PoolWithFailoverBase.h:320: PoolWithFailoverBase::getMany(unsigned long, unsigned long, unsigned long, unsigned long, bool, bool, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::function const&) @ 0x000000001c29f5e1 4. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:236: DB::ConnectionPoolWithFailover::getManyImpl(DB::Settings const&, DB::PoolMode, std::function::TryResult (std::shared_ptr const&, String&)> const&, std::optional, std::function, bool) @ 0x000000001c29b96a 5. ./build_docker/./src/Client/ConnectionPoolWithFailover.cpp:180: DB::ConnectionPoolWithFailover::getManyCheckedForInsert(DB::ConnectionTimeouts const&, DB::Settings const&, DB::PoolMode, DB::QualifiedTableName const&) @ 0x000000001c29bfd0 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:433: DB::DistributedAsyncInsertDirectoryQueue::processFile(String&, DB::SettingsChanges const&) @ 0x000000001b9a04c2 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:395: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000001b99ab58 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:172: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000001b99a7f5 9. ./build_docker/./src/Storages/StorageDistributed.cpp:1754: void std::__function::__policy_invoker::__call_impl, DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000001b2d94fe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000013719a18 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001371991e 12. ./contrib/llvm-project/libcxx/include/future:1876: std::packaged_task::operator()() @ 0x000000001371aa75 13. ./src/Common/threadPoolCallbackRunner.h:167: void std::__function::__policy_invoker::__call_impl>, std::function>::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001371a9ad 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:35.084346 [ 2170 ] {5495cad3-cad2-435c-8e6e-a56e3e787891} : Logical error: 'Replica info is not initialized'. 2025.04.02 09:40:35.160042 [ 2170 ] {5495cad3-cad2-435c-8e6e-a56e3e787891} : Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:727: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x00000000183b8a3c 5. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:623: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000183b5d6e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:562: DB::RemoteQueryExecutor::readAsync() @ 0x00000000183b7c0d 7. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001ca2dbfe 8. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 9. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001ca2d84d 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:49: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c52036a 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:35.162901 [ 2683 ] {} BaseDaemon: ########## Short fault info ############ 2025.04.02 09:40:35.163404 [ 2683 ] {} BaseDaemon: (version 24.12.2.20221.altinityantalya (altinity build), build id: 1D546DEA3F7DAB479A2081B78470431AC256AC96, git hash: 82252d159dc02cab0f366aaa5691adc1545dd11d, architecture: x86_64) (from thread 2170) Received signal 6 2025.04.02 09:40:35.163744 [ 2683 ] {} BaseDaemon: Signal description: Aborted 2025.04.02 09:40:35.163823 [ 2683 ] {} BaseDaemon: 2025.04.02 09:40:35.163945 [ 2683 ] {} BaseDaemon: Stack trace: 0x0000557016fa011d 0x000055701739d422 0x000055700e68c7a6 0x000055700e68ccfb 0x00007fd7c1fcd520 0x00007fd7c20219fd 0x00007fd7c1fcd476 0x00007fd7c1fb37f3 0x000055700e68b267 0x0000557016f58a0a 0x0000557016f59dff 0x000055700e711ade 0x000055700e7219ba 0x000055701ef34a3c 0x000055701ef31d6e 0x000055701ef33c0d 0x00005570235a9bfe 0x0000557023089f8b 0x00005570235a984d 0x00005570230aea47 0x000055702309e54c 0x000055702309d8cc 0x000055702309d5aa 0x000055702309c36a 0x000055701706b7ee 0x00005570170739dc 0x000055700e684428 0x00007fd7c201fac3 0x00007fd7c20b1850 2025.04.02 09:40:35.164119 [ 2683 ] {} BaseDaemon: ######################################## 2025.04.02 09:40:35.165045 [ 2683 ] {} BaseDaemon: (version 24.12.2.20221.altinityantalya (altinity build), build id: 1D546DEA3F7DAB479A2081B78470431AC256AC96, git hash: 82252d159dc02cab0f366aaa5691adc1545dd11d) (from thread 2170) (query_id: 5495cad3-cad2-435c-8e6e-a56e3e787891) (query: INSERT INTO distributed_01099_b SELECT * FROM urlCluster('test_cluster_two_shards', 'http://localhost:8123/?query=select+{1,2,3}+format+TSV', 'TSV', 's String');) Received signal Aborted (6) 2025.04.02 09:40:35.165988 [ 2683 ] {} BaseDaemon: 2025.04.02 09:40:35.166563 [ 2683 ] {} BaseDaemon: Stack trace: 0x0000557016fa011d 0x000055701739d422 0x000055700e68c7a6 0x000055700e68ccfb 0x00007fd7c1fcd520 0x00007fd7c20219fd 0x00007fd7c1fcd476 0x00007fd7c1fb37f3 0x000055700e68b267 0x0000557016f58a0a 0x0000557016f59dff 0x000055700e711ade 0x000055700e7219ba 0x000055701ef34a3c 0x000055701ef31d6e 0x000055701ef33c0d 0x00005570235a9bfe 0x0000557023089f8b 0x00005570235a984d 0x00005570230aea47 0x000055702309e54c 0x000055702309d8cc 0x000055702309d5aa 0x000055702309c36a 0x000055701706b7ee 0x00005570170739dc 0x000055700e684428 0x00007fd7c201fac3 0x00007fd7c20b1850 2025.04.02 09:40:35.369611 [ 2683 ] {} BaseDaemon: 0.0. inlined from ./build_docker/./src/Common/StackTrace.cpp:381: StackTrace::tryCapture() 2025.04.02 09:40:35.369941 [ 2683 ] {} BaseDaemon: 0. ./build_docker/./src/Common/StackTrace.cpp:350: StackTrace::StackTrace(ucontext_t const&) @ 0x000000001042411d 2025.04.02 09:40:35.507573 [ 2177 ] {876c2fce-a8e1-4496-bf3a-324e5eb15242} executeQuery: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:60044) (comment: 00983_summing_merge_tree_not_an_identifier.sql) (in query: CREATE TABLE xx (`date` Date, `id` Int64, `clicks` Int64, `price` Float64, `spend` Float64) ENGINE = SummingMergeTree([price, spend]) PARTITION BY toYYYYMM(date) ORDER BY id SAMPLE BY id SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.4998689889907837, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 415360970, compact_parts_max_granules_to_buffer = 162, compact_parts_merge_max_bytes_to_prefetch_part = 30788935, merge_max_block_size = 6326, old_parts_lifetime = 187., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6057726174, index_granularity_bytes = 5166807, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 52, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 38487, primary_key_compress_block_size = 39509, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:262: DB::getIdentifierName(DB::IAST const*) @ 0x000000001d4e80f5 5. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02addb 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:35.509726 [ 2177 ] {} TCPHandler: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Parsers/ASTIdentifier.cpp:262: DB::getIdentifierName(DB::IAST const*) @ 0x000000001d4e80f5 5. ./src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02addb 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:35.566929 [ 2683 ] {} BaseDaemon: 1. ./build_docker/./src/Common/SignalHandlers.cpp:102: signalHandler(int, siginfo_t*, void*) @ 0x0000000010821422 2025.04.02 09:40:41.719899 [ 2683 ] {} BaseDaemon: 2. __tsan::CallUserSignalHandler(__tsan::ThreadState*, bool, bool, int, __sanitizer::__sanitizer_siginfo*, void*) @ 0x0000000007b107a6 2025.04.02 09:40:49.015677 [ 1433 ] {834c8398-1901-463f-bd67-2473e2627482} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:40984) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:49.062635 [ 1433 ] {834c8398-1901-463f-bd67-2473e2627482} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:49.943174 [ 2180 ] {7cb7f505-8a51-4c00-9662-5efbc24e53fa} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column 'a': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57418) (comment: 02933_paste_join.sql) (in query: SELECT * FROM (SELECT 1 AS a) PASTE JOIN (SELECT 2 AS b) PASTE JOIN (SELECT 3 AS a) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000017fe56b4 4. ./build_docker/./src/Core/Block.cpp:37: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000017fe01a0 5. ./build_docker/./src/Core/Block.cpp:98: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000017fd5dba 6. ./build_docker/./src/Core/Block.cpp:198: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000017fd609d 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:802: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2f1c1 8. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 9. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 10. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:49.948948 [ 2180 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column 'a': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000017fe56b4 4. ./build_docker/./src/Core/Block.cpp:37: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x0000000017fe01a0 5. ./build_docker/./src/Core/Block.cpp:98: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000017fd5dba 6. ./build_docker/./src/Core/Block.cpp:198: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000017fd609d 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:802: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2f1c1 8. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 9. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 10. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:50.638432 [ 2180 ] {5520830b-b89c-4d72-8a8c-a4c2eafd526f} executeQuery: Code: 179. DB::Exception: Multiple table expressions with same alias test2.a. In scope SELECT * FROM test1 AS `test2.a` PASTE JOIN test2 AS `test2.a`. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57418) (comment: 02933_paste_join.sql) (in query: SELECT * FROM test1 `test2.a` PASTE JOIN test2 `test2.a`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x0000000008483466 4. ./src/Analyzer/Resolve/TableExpressionsAliasVisitor.h:62: DB::TableExpressionsAliasVisitor::updateAliasesIfNeeded(std::shared_ptr const&) @ 0x0000000018b06bab 5. ./src/Analyzer/Resolve/TableExpressionsAliasVisitor.h:25: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr&) @ 0x0000000018b06697 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a92f81 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:50.644769 [ 2180 ] {} TCPHandler: Code: 179. DB::Exception: Multiple table expressions with same alias test2.a. In scope SELECT * FROM test1 AS `test2.a` PASTE JOIN test2 AS `test2.a`. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x0000000008483466 4. ./src/Analyzer/Resolve/TableExpressionsAliasVisitor.h:62: DB::TableExpressionsAliasVisitor::updateAliasesIfNeeded(std::shared_ptr const&) @ 0x0000000018b06bab 5. ./src/Analyzer/Resolve/TableExpressionsAliasVisitor.h:25: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr&) @ 0x0000000018b06697 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a92f81 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:50.862814 [ 2180 ] {1ddd3fcd-bcdf-49a2-963c-8dc55ed814e0} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: a Int32 Int32(size = 0) a UInt64 UInt64(size = 0). (AMBIGUOUS_COLUMN_NAME) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57418) (comment: 02933_paste_join.sql) (in query: SELECT * FROM test1 PASTE JOIN (SELECT number AS a FROM numbers(2) ORDER BY number DESC);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000017fe4f6c 4. ./build_docker/./src/Core/Block.cpp:37: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000017fd562d 5. ./build_docker/./src/Core/Block.cpp:198: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000017fd609d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:836: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e5979 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 10. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 11. ./build_docker/./src/Planner/Planner.cpp:1846: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a46a6 12. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:50.866023 [ 2180 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: a Int32 Int32(size = 0) a UInt64 UInt64(size = 0). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x0000000017fe4f6c 4. ./build_docker/./src/Core/Block.cpp:37: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x0000000017fd562d 5. ./build_docker/./src/Core/Block.cpp:198: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x0000000017fd609d 6. ./build_docker/./src/Interpreters/ActionsDAG.cpp:836: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e5979 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 10. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 11. ./build_docker/./src/Planner/Planner.cpp:1846: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a46a6 12. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:54.043716 [ 3133 ] {3f0a07f0-3fc1-4abc-a34c-25be033c1213} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59650) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:54.108340 [ 3133 ] {3f0a07f0-3fc1-4abc-a34c-25be033c1213} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:58.543986 [ 2683 ] {} BaseDaemon: 3. sighandler(int, __sanitizer::__sanitizer_siginfo*, void*) @ 0x0000000007b10cfb 2025.04.02 09:40:58.550350 [ 2683 ] {} BaseDaemon: 4. ? @ 0x00007fd7c1fcd520 2025.04.02 09:40:58.552001 [ 2683 ] {} BaseDaemon: 5. ? @ 0x00007fd7c20219fd 2025.04.02 09:40:58.552734 [ 2683 ] {} BaseDaemon: 6. ? @ 0x00007fd7c1fcd476 2025.04.02 09:40:58.552991 [ 2683 ] {} BaseDaemon: 7. ? @ 0x00007fd7c1fb37f3 2025.04.02 09:40:59.275448 [ 1424 ] {c8f4e7b3-9900-42a9-8b6f-abff4515f4a1} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60074) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:59.300936 [ 1424 ] {c8f4e7b3-9900-42a9-8b6f-abff4515f4a1} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:40:59.531292 [ 1424 ] {cf65beb2-6692-4abf-96cc-9171c9708caf} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:60082) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:40:59.553353 [ 1424 ] {cf65beb2-6692-4abf-96cc-9171c9708caf} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:05.067217 [ 1433 ] {eeb1140c-138c-4a7d-95f6-1fc3d518ea64} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59082) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:05.093509 [ 1433 ] {eeb1140c-138c-4a7d-95f6-1fc3d518ea64} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:05.897588 [ 1436 ] {a707538e-ae1e-40dc-bdec-5a068879da47} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59094) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:05.958811 [ 1436 ] {a707538e-ae1e-40dc-bdec-5a068879da47} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:06.760232 [ 1429 ] {05e14f31-cf3d-4271-8346-634a93fcd949} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59110) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:06.766692 [ 1429 ] {05e14f31-cf3d-4271-8346-634a93fcd949} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:06.882649 [ 1424 ] {514f0f99-58ef-4a98-b993-b5ed23cef731} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59116) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:06.887363 [ 1424 ] {514f0f99-58ef-4a98-b993-b5ed23cef731} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:06.989377 [ 2177 ] {d4774b6c-697e-4020-a15a-df20cb218167} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59124) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:06.994665 [ 2177 ] {d4774b6c-697e-4020-a15a-df20cb218167} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.092921 [ 1424 ] {79f7c93d-654c-4626-986a-48075d5f4fb1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59140) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.097873 [ 1424 ] {79f7c93d-654c-4626-986a-48075d5f4fb1} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.205890 [ 1436 ] {40cf4f39-6132-44a1-999f-9078025f3448} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59144) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.220237 [ 1436 ] {40cf4f39-6132-44a1-999f-9078025f3448} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.297898 [ 1424 ] {ad94c8e5-7514-466a-b663-e0fc81b879ba} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59146) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.302655 [ 1424 ] {ad94c8e5-7514-466a-b663-e0fc81b879ba} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.397421 [ 1436 ] {bb4abee3-f415-49bc-bb15-e0dcdbca29d5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59160) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.406930 [ 1436 ] {bb4abee3-f415-49bc-bb15-e0dcdbca29d5} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.468715 [ 2177 ] {54a05900-f37f-4c47-b421-ad90b66cef99} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59166) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.474675 [ 2177 ] {54a05900-f37f-4c47-b421-ad90b66cef99} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.553640 [ 1436 ] {36a356fd-d29e-4e39-827c-61fdf16f7b42} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59176) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.562906 [ 1436 ] {36a356fd-d29e-4e39-827c-61fdf16f7b42} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.649400 [ 1424 ] {8e52c7f9-979b-4c86-8c95-973c41b01bf3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59182) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.653729 [ 1424 ] {8e52c7f9-979b-4c86-8c95-973c41b01bf3} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.726691 [ 1433 ] {93398e03-b8ea-410e-b223-b6d2d8fe0a56} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59196) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.733490 [ 1433 ] {93398e03-b8ea-410e-b223-b6d2d8fe0a56} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.826218 [ 3133 ] {4d759f6e-89ea-4903-8477-3ef9477ba0ff} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59212) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from numbers(10) format XML settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.830659 [ 3133 ] {4d759f6e-89ea-4903-8477-3ef9477ba0ff} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:07.946484 [ 1436 ] {19ef2f14-441e-40fd-98df-6226725eae4b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59214) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:07.956564 [ 1436 ] {19ef2f14-441e-40fd-98df-6226725eae4b} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.021987 [ 1433 ] {81e11d78-31bf-4864-8ed4-c2824b62e38f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59222) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.026955 [ 1433 ] {81e11d78-31bf-4864-8ed4-c2824b62e38f} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.092152 [ 1429 ] {56ff6371-b135-48b4-a832-35e5bc6ea0ee} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59236) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.100059 [ 1429 ] {56ff6371-b135-48b4-a832-35e5bc6ea0ee} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.160100 [ 1436 ] {e6fd169b-9d36-49c4-818b-92084499923c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59244) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.163203 [ 1436 ] {e6fd169b-9d36-49c4-818b-92084499923c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.226984 [ 1429 ] {5bfad315-c71c-44f6-a923-ffb5076e75b7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59258) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.231629 [ 1429 ] {5bfad315-c71c-44f6-a923-ffb5076e75b7} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.293662 [ 3133 ] {00b8db95-4d39-4694-8465-2dc6cc96ba15} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59260) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format XML settings max_block_size=1, output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.307916 [ 3133 ] {00b8db95-4d39-4694-8465-2dc6cc96ba15} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.375787 [ 1429 ] {d69b7bbd-e524-409b-97c7-75357475e796} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59270) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSON settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.415909 [ 1429 ] {d69b7bbd-e524-409b-97c7-75357475e796} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:08.902456 [ 3133 ] {8e621ab9-a5e7-4272-ac33-033a4448036b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59274) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompact settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:08.950406 [ 3133 ] {8e621ab9-a5e7-4272-ac33-033a4448036b} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:09.401581 [ 1429 ] {9f1ebc41-909f-4298-a4a4-6c98cd2710c3} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59282) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONObjectEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:09.430157 [ 1429 ] {9f1ebc41-909f-4298-a4a4-6c98cd2710c3} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:09.894375 [ 1433 ] {4ee41dbe-ce4a-495f-8ef5-950afad864c2} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59296) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:09.918238 [ 1433 ] {4ee41dbe-ce4a-495f-8ef5-950afad864c2} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:10.406189 [ 1424 ] {1138bc66-15b1-4d4f-a454-006f43189b4c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:59310) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select number, throwIf(number > 3) as res from system.numbers format JSONCompactEachRow settings max_block_size=1, output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:10.442936 [ 1424 ] {1138bc66-15b1-4d4f-a454-006f43189b4c} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(greater(number, 3) :: 2) -> throwIf(greater(number, 3)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72ee71 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 11. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:112: DB::CompletedPipelineExecutor::execute() @ 0x000000001c51fd8b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1798: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000019e26dac 19. ./build_docker/./src/Server/HTTPHandler.cpp:582: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35f672 20. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:16.620647 [ 2177 ] {f8ea28a2-6ff5-4aee-9fb4-f4ff66597439} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39456) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:16.629485 [ 2177 ] {f8ea28a2-6ff5-4aee-9fb4-f4ff66597439} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:16.766580 [ 1433 ] {2467cba4-b59e-46d4-b1d1-0d656c965325} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39460) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:16.770609 [ 1433 ] {2467cba4-b59e-46d4-b1d1-0d656c965325} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:16.944711 [ 1429 ] {a0a2bfc9-fcec-4ddf-a1eb-35478c5fb7c8} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39470) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompact settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:16.953213 [ 1429 ] {a0a2bfc9-fcec-4ddf-a1eb-35478c5fb7c8} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:17.062961 [ 1433 ] {b8a27511-c9bb-4291-bc77-3d49b399201c} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39482) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONCompactEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:17.075131 [ 1433 ] {b8a27511-c9bb-4291-bc77-3d49b399201c} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONCompactEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:17.214517 [ 1436 ] {7c786961-28cb-4cbc-8b1c-ebdf2fc129c3} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39492) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format JSONObjectEachRow settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:17.217493 [ 1436 ] {7c786961-28cb-4cbc-8b1c-ebdf2fc129c3} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONObjectEachRowRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:17.352380 [ 3133 ] {c0bc4b44-b927-4553-9597-182b21c36581} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39494) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 order by x format XML settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852ceba 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:77: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c8afbee 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:17.359284 [ 3133 ] {c0bc4b44-b927-4553-9597-182b21c36581} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing XMLRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextXML(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852ceba 6. ./build_docker/./src/Processors/Formats/Impl/XMLRowOutputFormat.cpp:77: DB::XMLRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c8afbee 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:17.914849 [ 2177 ] {81cd4999-9835-4641-b02a-2158ca9ac922} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39500) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:17.949752 [ 2177 ] {81cd4999-9835-4641-b02a-2158ca9ac922} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:18.194230 [ 2177 ] {026a4b94-bbc7-4e3e-af36-018fd0bf57d4} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39510) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompact settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:18.240923 [ 2177 ] {026a4b94-bbc7-4e3e-af36-018fd0bf57d4} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONCompactRowOutputFormat.cpp:23: DB::JSONCompactRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e0f11 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:18.732455 [ 3133 ] {5b18c630-2bcb-4981-9ffd-c8b6e300ae3e} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39524) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONObjectEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:18.754331 [ 3133 ] {5b18c630-2bcb-4981-9ffd-c8b6e300ae3e} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/Impl/JSONObjectEachRowRowOutputFormat.cpp:22: DB::JSONObjectEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6ecba2 9. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::JSONObjectEachRowRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6ecebe 11. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 12. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 13. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:18.915371 [ 2683 ] {} BaseDaemon: 8. ___interceptor_abort @ 0x0000000007b0f267 2025.04.02 09:41:19.497305 [ 1436 ] {b7d70765-5b96-4f76-8fdd-bed6d44ba776} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39538) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:19.538230 [ 1436 ] {b7d70765-5b96-4f76-8fdd-bed6d44ba776} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowOutputFormat.cpp:29: DB::JSONEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6e88b8 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:19.730227 [ 2683 ] {} BaseDaemon: 9. ./build_docker/./src/Common/Exception.cpp:48: DB::abortOnFailedAssertion(String const&, void* const*, unsigned long, unsigned long) @ 0x00000000103dca0a 2025.04.02 09:41:19.946326 [ 2683 ] {} BaseDaemon: 10.0. inlined from ./build_docker/./src/Common/Exception.cpp:70: DB::handle_error_code(String const&, int, bool, std::vector> const&) 2025.04.02 09:41:19.949528 [ 2683 ] {} BaseDaemon: 10. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dddff 2025.04.02 09:41:19.970983 [ 3133 ] {8f949919-7691-4049-8959-048f4643fbe6} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:39554) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSONCompactEachRow settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:20.022853 [ 3133 ] {8f949919-7691-4049-8959-048f4643fbe6} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Processors/Formats/Impl/JSONCompactEachRowRowOutputFormat.cpp:38: DB::JSONCompactEachRowRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6dc785 7. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 8. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 10. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 11. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:22.615209 [ 1424 ] {fe952727-8700-415b-a05a-690f8e205088} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37496) (comment: 02534_keyed_siphash.sql) (in query: select sipHash64Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2b30 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2bfc4 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2b8fe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:22.623151 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2b30 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2bfc4 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2b8fe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:22.796603 [ 1424 ] {efe1fa53-6df3-42fd-853a-e27df60b54e8} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37496) (comment: 02534_keyed_siphash.sql) (in query: select sipHash128Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2b30 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaaabe 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaa63e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:22.798731 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2b30 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaaabe 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaa63e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:23.039937 [ 1424 ] {b92f4709-b650-4f85-aeb8-fc9a5230705e} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37496) (comment: 02534_keyed_siphash.sql) (in query: select sipHash64Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2abf 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2bfc4 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2b8fe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:23.041629 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2abf 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2bfc4 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007e2b8fe 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:23.203035 [ 1424 ] {3fc9c174-66d6-4bf0-b559-bc10f40474a3} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37496) (comment: 02534_keyed_siphash.sql) (in query: select sipHash128Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2abf 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaaabe 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaa63e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:23.204936 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x0000000007df2abf 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaaabe 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007eaa63e 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:41:28.414887 [ 1424 ] {767d9490-9449-4515-906c-025ba396a57b} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37496) (comment: 02534_keyed_siphash.sql) (in query: SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Columns/ColumnNullable.cpp:49: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x000000001ad3e3b8 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f3cac9 6. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f2fbd9 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f41c 8. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f3e0 9. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f3c1e6 10. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f2fc69 11. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f41c 12. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f3e0 13. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007f2ee43 14. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 15. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007f2e7de 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 2025.04.02 09:41:28.425862 [ 1424 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(UInt16) in case if value is NULL: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Columns/ColumnNullable.cpp:49: DB::ColumnNullable::getDataAt(unsigned long) const @ 0x000000001ad3e3b8 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeGeneric(DB::impl::SipHashKeyColumns const&, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f3cac9 6. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f2fbd9 7. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f41c 8. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f3e0 9. void DB::TargetSpecific::Default::FunctionAnyHash::executeArray(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f3c1e6 10. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&) const @ 0x0000000007f2fc69 11. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f41c 12. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(DB::impl::SipHashKeyColumns const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, bool&) const @ 0x0000000007f2f3e0 13. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007f2ee43 14. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007de1cbc 15. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007f2e7de 16. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 19. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 2025.04.02 09:41:29.187315 [ 1435 ] {5fcc3b0d-ae2c-4e2c-8304-616fadc55c03} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57408) (comment: 02364_multiSearch_function_family.sql) (in query: select multiSearchAllPositions(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x000000000cf22146 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf21836 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000189e6f7b 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e57cb 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 16. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a07e1 17. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:29.198775 [ 1435 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, unsigned long&&) @ 0x000000000cf22146 4. DB::FunctionsMultiStringPosition>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf21836 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000189e6f7b 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e57cb 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 16. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a07e1 17. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:29.410614 [ 1435 ] {7bf5b4a4-29f6-4ecd-bb26-097aecae8a02} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:57408) (comment: 02364_multiSearch_function_family.sql) (in query: select multiSearchFirstIndex(materialize('string'), ['o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'o', 'str']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x0000000009e83cec 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf416d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000189e6f7b 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e57cb 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 16. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a07e1 17. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:29.424026 [ 1435 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 256, should be at most 255. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const* const&, String&&, String&&) @ 0x0000000009e83cec 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf416d2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:742: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000189e6f7b 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:822: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000189e57cb 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001c8f2c0a 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000001cb5c735 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::Block const&, DB::ActionsDAG&&) @ 0x0000000017717282 15. ./build_docker/./src/Planner/Planner.cpp:394: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x00000000199a8f25 16. ./build_docker/./src/Planner/Planner.cpp:1656: DB::Planner::buildPlanForQueryNode() @ 0x00000000199a07e1 17. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 21. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 22. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:35.275619 [ 1433 ] {fdcbf88d-dfc7-4150-abe2-ca95e1fe2384} executeQuery: Code: 344. DB::Exception: OPTIMIZE DEDUPLICATE query is not supported for table test_projection_deduplicate as it has projections. User should drop all the projections manually before running the query, or consider drop or rebuild option of deduplicate_merge_projection_mode. (SUPPORT_IS_DISABLED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:58798) (comment: 03174_projection_deduplicate.sql) (in query: OPTIMIZE TABLE test_projection_deduplicate DEDUPLICATE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1621: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001c05090e 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000019e8afaa 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:35.283023 [ 1433 ] {} TCPHandler: Code: 344. DB::Exception: OPTIMIZE DEDUPLICATE query is not supported for table test_projection_deduplicate as it has projections. User should drop all the projections manually before running the query, or consider drop or rebuild option of deduplicate_merge_projection_mode. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1621: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000001c05090e 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000019e8afaa 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:37.775437 [ 2177 ] {927bcb04-cc05-4513-b0f0-489b468c5f07} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50826) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:37.872779 [ 2177 ] {927bcb04-cc05-4513-b0f0-489b468c5f07} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:40.271820 [ 1424 ] {6eb1f7c7-112c-42cf-848c-6218ee282cc8} executeQuery: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_lfm3srwc/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:58812) (comment: 02400_create_table_on_cluster_normalization.sql) (in query: -- Correct error code if creating database with the same path as table has create database local_t_l5ydey engine=Replicated('/clickhouse/tables/test_' || currentDatabase() || '/{shard}/local_t_l5ydey', '1', '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007bb9200 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:641: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000001868fc39 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:527: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000018689bff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:729: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001869190a 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000194ec75a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:415: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000194b630e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2323: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc30a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:40.278733 [ 1424 ] {} TCPHandler: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_lfm3srwc/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007bb9200 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:641: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x000000001868fc39 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:527: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000018689bff 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:729: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001869190a 7. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000194ec75a 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:415: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000194b630e 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2323: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc30a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:40.626177 [ 2683 ] {} BaseDaemon: 11. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 2025.04.02 09:41:40.747969 [ 2180 ] {0db20f1e-d5a3-4824-ac94-693643519d65} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:58820) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary1` ( `n1` String, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b72d3c0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:66: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001b2ae048 5. ./build_docker/./src/Storages/StorageDictionary.cpp:123: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001b2ae661 6. ./build_docker/./src/Storages/StorageDictionary.cpp:134: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001b2ae916 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001b2b3679 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001b2b20af 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:40.754288 [ 2180 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is String. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b72d3c0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:66: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001b2ae048 5. ./build_docker/./src/Storages/StorageDictionary.cpp:123: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001b2ae661 6. ./build_docker/./src/Storages/StorageDictionary.cpp:134: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001b2ae916 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001b2b3679 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001b2b20af 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:40.791803 [ 2180 ] {c24c58d1-92ff-4a28-9c00-d0948a14a2db} executeQuery: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:58820) (comment: 03198_dictionary_validate_primary_key_type.sql) (in query: CREATE DICTIONARY `test_dictionary2` ( `n1` UInt32, `n2` UInt32 ) PRIMARY KEY n1 SOURCE(CLICKHOUSE(HOST 'localhost' PORT 9000 DB 'test_db' TABLE 'table_01' USER 'default')) LIFETIME(MIN 1 MAX 10) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b72d3c0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:66: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001b2ae048 5. ./build_docker/./src/Storages/StorageDictionary.cpp:123: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001b2ae661 6. ./build_docker/./src/Storages/StorageDictionary.cpp:134: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001b2ae916 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001b2b3679 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001b2b20af 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:40.798839 [ 2180 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect type of ID column: must be UInt64, but it is UInt32. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000b72d3c0 4. ./build_docker/./src/Storages/StorageDictionary.cpp:66: DB::StorageDictionary::getNamesAndTypes(DB::DictionaryStructure const&, bool) @ 0x000000001b2ae048 5. ./build_docker/./src/Storages/StorageDictionary.cpp:123: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, String const&, DB::DictionaryStructure const&, String const&, DB::StorageDictionary::Location, std::shared_ptr) @ 0x000000001b2ae661 6. ./build_docker/./src/Storages/StorageDictionary.cpp:134: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000001b2ae916 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, void>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x000000001b2b3679 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001b2b20af 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:43.465690 [ 1436 ] {54625657-fe18-4bc5-a653-38e757080263} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:50834) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:43.520107 [ 1436 ] {54625657-fe18-4bc5-a653-38e757080263} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:48.162080 [ 1424 ] {185334e8-6411-44d7-b154-af3eab104c8e} executeQuery: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36290) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance(tuple(1), tuple(1, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000007c838ac 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d9eb7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:41:48.178369 [ 1424 ] {} TCPHandler: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000007c838ac 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e8d9eb7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:41:48.414010 [ 1424 ] {c64f17a7-cf3b-46bd-9dd4-519ff5851d8d} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36290) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance(tuple(1), tuple('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000d253922 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d23713c 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8d55fe 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 2025.04.02 09:41:48.419337 [ 1424 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000d253922 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d23713c 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8d55fe 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 2025.04.02 09:41:48.437489 [ 1424 ] {01915f8c-d8a3-4655-94f8-407a8531f0a4} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36290) (comment: 01653_tuple_hamming_distance_2.sql) (in query: SELECT tupleHammingDistance((1, 3), (3, 'a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000d253922 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d23713c 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8d55fe 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 2025.04.02 09:41:48.440136 [ 1424 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d79b6a6 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000184cbac0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000184d1c6a 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000d253922 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d23713c 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 13. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8d55fe 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 2025.04.02 09:41:48.869819 [ 2180 ] {d870aed5-1bc9-4d9f-9d16-2cdd18c12685} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53626) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:48.913412 [ 2180 ] {d870aed5-1bc9-4d9f-9d16-2cdd18c12685} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:49.757811 [ 2177 ] {a4e97d75-60dc-43f7-bc3e-d8f5b681871b} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:53636) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:49.798221 [ 2177 ] {a4e97d75-60dc-43f7-bc3e-d8f5b681871b} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:51.969765 [ 1424 ] {4567a48d-aec4-483b-bb9c-78fb695f3a0d} executeQuery: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_tqsltand.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36330) (comment: 01297_alter_distributed.sql) (in query: select CounterID, dummy1 from merge_distributed where dummy1 <> '' limit 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000018b265f4 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:867: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000018b1f0ae 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:971: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018b1ff6d 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1510: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018b21ffd 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000018b24337 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1468: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000018aadbfa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3671: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b86f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000019513544 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000019513398 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:147: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ca9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:48: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000001cb5b7d2 20. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:168: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000001aaf604c 21. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:241: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000001aaf3f7c 22. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:318: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000001aaf6409 23. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:368: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000001aae0243 24. ./build_docker/./src/Storages/StorageDistributed.cpp:902: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b2c0bfc 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c47c5 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 27. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 28. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 2025.04.02 09:41:51.981123 [ 1424 ] {} TCPHandler: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_tqsltand.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000018b265f4 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:867: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000018b1f0ae 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:971: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018b1ff6d 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1510: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018b21ffd 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000018b24337 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1468: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x0000000018aadbfa 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3671: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b86f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:209: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x0000000019513544 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:194: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000019513398 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:147: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ca9 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./build_docker/./src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:48: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x000000001cb5b7d2 20. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:168: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x000000001aaf604c 21. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:241: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x000000001aaf3f7c 22. ./build_docker/./src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:318: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x000000001aaf6409 23. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:368: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x000000001aae0243 24. ./build_docker/./src/Storages/StorageDistributed.cpp:902: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b2c0bfc 25. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c47c5 26. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 27. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 28. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 2025.04.02 09:41:53.120853 [ 3133 ] {c8e7910e-98e7-4977-ad7e-83b16523fd43} executeQuery: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36382) (comment: 03006_analyzer_executable_table_function.sql) (in query: SELECT toFixedString(toFixedString(toLowCardinality(toFixedString('--------------------', toNullable(20))), toLowCardinality(20)), 20), * FROM executable('data String', SETTINGS max_command_execution_time = 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001347cc9f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4813: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000018a9feb3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000018ad16d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a92fd4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:53.129916 [ 3133 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000001347cc9f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4813: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000018a9feb3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5295: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000018ad16d9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5552: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a92fd4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 17. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:55.717329 [ 1436 ] {773dd1ba-c078-406a-bea6-5244a95b17e5} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49732) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:56.013417 [ 1436 ] {773dd1ba-c078-406a-bea6-5244a95b17e5} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing JSONRowOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:87: DB::IOutputFormat::work() @ 0x000000001c5434fe 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:57.146289 [ 3133 ] {3247de7d-0c49-434b-b83a-7da37c3022cb} executeQuery: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:49746) (comment: 02841_valid_json_and_xml_on_http_exception.sh) (in query: select * from test_02841 format JSON settings output_format_parallel_formatting=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:41:57.172681 [ 3133 ] {3247de7d-0c49-434b-b83a-7da37c3022cb} DynamicQueryHandler: Code: 691. DB::Exception: Unexpected value 99 in enum: While executing ParallelFormattingOutputFormat. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: DB::SerializationEnum<_BitInt(8)>::serializeTextJSON(DB::IColumn const&, unsigned long, DB::WriteBuffer&, DB::FormatSettings const&) const @ 0x000000001852c781 6. ./build_docker/./src/Formats/JSONUtils.cpp:430: DB::JSONUtils::writeFieldFromColumn(DB::IColumn const&, DB::ISerialization const&, unsigned long, bool, DB::FormatSettings const&, DB::WriteBuffer&, std::optional const&, unsigned long, char const*, bool) @ 0x000000001c4b2439 7. ./build_docker/./src/Processors/Formats/Impl/JSONRowOutputFormat.cpp:34: DB::JSONRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000001c6efc66 8. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c54536e 9. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:60: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000001c6de6ca 10. ./src/Processors/Formats/RowOutputFormatWithExceptionHandlerAdaptor.h:47: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::consume(DB::Chunk) @ 0x000000001c6de2e5 11. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:238: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000001c760742 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:303: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c7623d8 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:41:57.988457 [ 2683 ] {} BaseDaemon: 12. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 2025.04.02 09:42:00.113547 [ 2177 ] {0ee4d4ee-e96c-49ca-881e-1721cf4209c1} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.12.2.20221.altinityantalya (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:40172) (comment: 02416_json_object_inference.sql) (in query: desc format(JSONEachRow, '{"a" : {"b" : {"c" : 1, "d" : "str"}}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e477ae6 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:488: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001c4cbab4 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:549: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001c4cd0f4 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000134ce1b1 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000019e953ff 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000019e9413e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:00.119037 [ 2177 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'a' by first 1 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 24.12.2.20221.altinityantalya (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e477ae6 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:488: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001c4cbab4 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:549: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001c4cd0f4 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000134ce1b1 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000019e953ff 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000019e9413e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:02.121691 [ 2683 ] {} BaseDaemon: 13. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:727: DB::RemoteQueryExecutor::processReadTaskRequest() @ 0x00000000183b8a3c 2025.04.02 09:42:02.526694 [ 2683 ] {} BaseDaemon: 14. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:623: DB::RemoteQueryExecutor::processPacket(DB::Packet) @ 0x00000000183b5d6e 2025.04.02 09:42:02.580286 [ 3992 ] {c27424ddbf4a4b8cbede771b8d0abb93} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:32788). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:02.586555 [ 3992 ] {c27424ddbf4a4b8cbede771b8d0abb93} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:32788). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::ffff:127.0.0.1]:32788) (in query: select 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:02.591762 [ 3992 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:32788). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:02.984820 [ 2683 ] {} BaseDaemon: 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:562: DB::RemoteQueryExecutor::readAsync() @ 0x00000000183b7c0d 2025.04.02 09:42:03.568477 [ 2683 ] {} BaseDaemon: 16. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:182: DB::RemoteSource::tryGenerate() @ 0x000000001ca2dbfe 2025.04.02 09:42:03.880034 [ 2683 ] {} BaseDaemon: 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 2025.04.02 09:42:03.988427 [ 2683 ] {} BaseDaemon: 18. ./build_docker/./src/Processors/Sources/RemoteSource.cpp:134: DB::RemoteSource::work() @ 0x000000001ca2d84d 2025.04.02 09:42:04.260448 [ 2683 ] {} BaseDaemon: 19.0. inlined from ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) 2025.04.02 09:42:04.269401 [ 2683 ] {} BaseDaemon: 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:98: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 2025.04.02 09:42:05.376232 [ 2683 ] {} BaseDaemon: 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 2025.04.02 09:42:06.230286 [ 2683 ] {} BaseDaemon: 21.0. inlined from ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeSingleThread(unsigned long) 2025.04.02 09:42:06.231304 [ 2683 ] {} BaseDaemon: 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:442: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 2025.04.02 09:42:06.373556 [ 2683 ] {} BaseDaemon: 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 2025.04.02 09:42:06.671125 [ 2683 ] {} BaseDaemon: 23.0. inlined from ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:49: DB::threadFunction(DB::CompletedPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) 2025.04.02 09:42:06.675053 [ 2683 ] {} BaseDaemon: 23.1. inlined from ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:89: operator() 2025.04.02 09:42:06.675906 [ 2683 ] {} BaseDaemon: 23.2. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? 2025.04.02 09:42:06.676393 [ 2683 ] {} BaseDaemon: 23.3. inlined from ./contrib/llvm-project/libcxx/include/tuple:1789: _ZNSt3__118__apply_tuple_implB6v15007IRZN2DB25CompletedPipelineExecutor7executeEvE3$_0RNS_5tupleIJEEETpTnmJEEEDcOT_OT0_NS_15__tuple_indicesIJXspT1_EEEE 2025.04.02 09:42:06.678745 [ 2683 ] {} BaseDaemon: 23.4. inlined from ./contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15007]&>(DB::CompletedPipelineExecutor::execute()::$_0&, std::tuple<>&) 2025.04.02 09:42:06.680546 [ 2683 ] {} BaseDaemon: 23.5. inlined from ./src/Common/ThreadPool.h:311: operator() 2025.04.02 09:42:06.681280 [ 2683 ] {} BaseDaemon: 23.6. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? 2025.04.02 09:42:06.681932 [ 2683 ] {} BaseDaemon: 23.7. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:479: ? 2025.04.02 09:42:06.682611 [ 2683 ] {} BaseDaemon: 23.8. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:235: ? 2025.04.02 09:42:06.685281 [ 2683 ] {} BaseDaemon: 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001c52036a 2025.04.02 09:42:07.228552 [ 2683 ] {} BaseDaemon: 24.0. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? 2025.04.02 09:42:07.231516 [ 2683 ] {} BaseDaemon: 24.1. inlined from ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? 2025.04.02 09:42:07.231787 [ 2683 ] {} BaseDaemon: 24. ./build_docker/./src/Common/ThreadPool.cpp:785: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000104ef7ee 2025.04.02 09:42:07.591536 [ 2683 ] {} BaseDaemon: 25.0. inlined from ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? 2025.04.02 09:42:07.595342 [ 2683 ] {} BaseDaemon: 25.1. inlined from ./contrib/llvm-project/libcxx/include/thread:284: void std::__thread_execute[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*, 2ul>(std::tuple>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>&, std::__tuple_indices<2ul>) 2025.04.02 09:42:07.596206 [ 2683 ] {} BaseDaemon: 25. ./contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000104f79dc 2025.04.02 09:42:18.229628 [ 3992 ] {40b85074-5582-495d-8155-ab903aecca16} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44840) (comment: 02996_nullable_arrayReduce.sql) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/59600 SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.236961 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('stddevSampOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.301153 [ 3992 ] {5b7fd406-0106-4e7b-bb77-6a293e096e4d} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44840) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.302766 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toNullable('median'), [toDecimal32OrNull(toFixedString('1', 1), 2), 8]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.328982 [ 3992 ] {c25b652c-2b38-4290-a1c4-7f41d1ccc756} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44840) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.332914 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT toFixedString('--- Int Empty ---', toLowCardinality(17)), arrayReduce(toNullable('avgOrNull'), [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.515457 [ 3992 ] {bba2eb38-0fc3-4f5b-bf26-d4db980e5a67} executeQuery: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44840) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce('any', toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e5768ac 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bda2 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.518675 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arrayReduce must be an array but it has type Nullable(UInt8).: In scope SELECT arrayReduce('any', toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, String&&, String&&) @ 0x000000000e5768ac 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bda2 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.545048 [ 3992 ] {afc39082-da47-4324-bff2-9e0fe31c4ea9} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44840) (comment: 02996_nullable_arrayReduce.sql) (in query: SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.548632 [ 3992 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(toLowCardinality('median'), [toLowCardinality(toNullable(8))]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::FunctionArrayReduce::getReturnTypeImpl(std::vector> const&) const @ 0x000000000fd4bbc5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a588a 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 23. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 24. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 30. __tsan_thread_start_func @ 0x0000000007b08428 31. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:18.676430 [ 2177 ] {996ec66c-b260-4f4d-96a3-1a61f0385b14} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44848) (comment: 02366_with_fill_date.sql) (in query: SELECT toDate('2022-02-01') AS d1 FROM numbers(18) AS number ORDER BY d1 ASC WITH FILL FROM toDateTime('2022-02-01') TO toDateTime('2022-07-01') STEP toIntervalMonth(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:258: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb67607 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:18.681819 [ 2177 ] {} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:258: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb67607 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.087603 [ 2293 ] {bd3ebb3c-02e9-43b8-a7fa-c2f979f79293} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.097938 [ 1436 ] {bd3ebb3c-02e9-43b8-a7fa-c2f979f79293} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', 'abcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.100728 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.118792 [ 2294 ] {1c4994a5-d24d-48ee-b9db-2b92d62b53a5} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.121194 [ 1436 ] {1c4994a5-d24d-48ee-b9db-2b92d62b53a5} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2bcdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.122670 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.146517 [ 2288 ] {1858b366-1d6e-4823-a398-03d1aa334861} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.151670 [ 1436 ] {1858b366-1d6e-4823-a398-03d1aa334861} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20cdefgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.157477 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cdefgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.177469 [ 2075 ] {07a3d00d-6bbe-4be6-bac3-2ae3bbfafeba} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.183269 [ 1436 ] {07a3d00d-6bbe-4be6-bac3-2ae3bbfafeba} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202defgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.186404 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202defgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.334066 [ 3039 ] {6e61564b-4b28-400d-a8ba-8210e37b9820} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.338514 [ 1436 ] {6e61564b-4b28-400d-a8ba-8210e37b9820} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020efgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.342261 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020efgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.482744 [ 2299 ] {21a439a8-7a93-419f-b03e-f939f8455bd0} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.487088 [ 1436 ] {21a439a8-7a93-419f-b03e-f939f8455bd0} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20200fgh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.491852 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20200fgh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.513432 [ 2308 ] {b4e8659b-f09e-4af0-8846-8e6cb489f48a} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.520711 [ 1436 ] {b4e8659b-f09e-4af0-8846-8e6cb489f48a} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202001gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.526753 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202001gh,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.545031 [ 2307 ] {76b965ed-9ed1-4319-b64c-38dee11e747e} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.548338 [ 1436 ] {76b965ed-9ed1-4319-b64c-38dee11e747e} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020010h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.550593 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020010h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:782: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e64 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.705299 [ 3038 ] {a18baa35-cc3d-4461-b961-437c92aad728} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.708713 [ 1436 ] {a18baa35-cc3d-4461-b961-437c92aad728} executeQuery: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', 'abcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.710628 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: abcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:24.745579 [ 3040 ] {2a70853e-2788-4c9a-8d03-95e23e3d88e0} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:24.747786 [ 2683 ] {} BaseDaemon: 26. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:42:24.749564 [ 2683 ] {} BaseDaemon: 27. ? @ 0x00007fd7c201fac3 2025.04.02 09:42:24.749778 [ 2683 ] {} BaseDaemon: 28. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.541566 [ 2683 ] {} BaseDaemon: Integrity check of the executable successfully passed (checksum: CAD5C347B3B532C05434FCAB6F84FB12) 2025.04.02 09:42:37.657384 [ 1436 ] {2a70853e-2788-4c9a-8d03-95e23e3d88e0} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2bcd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.669741 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2bcd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.789820 [ 2308 ] {f1c67b70-a250-4b50-9632-bfdcf35a34ed} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:37.796097 [ 1436 ] {f1c67b70-a250-4b50-9632-bfdcf35a34ed} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '20cd-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.799489 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 20cd-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.822312 [ 2302 ] {f09b4464-de79-4551-b4ea-ee1df59e8cc9} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:37.826699 [ 1436 ] {f09b4464-de79-4551-b4ea-ee1df59e8cc9} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '202d-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.830135 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 202d-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8f4e 5. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 6. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 9. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 10. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 15. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 16. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 17. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.861877 [ 2286 ] {d29b07e7-d6ce-47de-9be4-c1af4c3338e4} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:37.867569 [ 1436 ] {d29b07e7-d6ce-47de-9be4-c1af4c3338e4} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-ef-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.869643 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-ef-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.893577 [ 3038 ] {a2c1f755-26b2-480f-bb46-936ff8fa1cf4} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:37.897727 [ 1436 ] {a2c1f755-26b2-480f-bb46-936ff8fa1cf4} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.901722 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.927611 [ 3059 ] {07916821-b621-4376-a9f9-50b5d1d63a2f} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:37.930756 [ 1436 ] {07916821-b621-4376-a9f9-50b5d1d63a2f} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-f-g,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:37.933054 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-f-g,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:794: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e6f 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.525389 [ 2068 ] {bb8d04bb-dcbf-4940-a0eb-7d20847374b6} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:39.550742 [ 1436 ] {bb8d04bb-dcbf-4940-a0eb-7d20847374b6} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-0f-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.553026 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-0f-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.603011 [ 2169 ] {ff383f35-085f-483a-8a22-bf4f32e999fb} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:39.610001 [ 1436 ] {ff383f35-085f-483a-8a22-bf4f32e999fb} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-01-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.615955 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-gh: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.638983 [ 3098 ] {3b609753-27a3-468f-b470-600806f783f7} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:39.645305 [ 1436 ] {3b609753-27a3-468f-b470-600806f783f7} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-01-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.653229 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-01-h,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.676402 [ 2075 ] {25fd32e4-4a8b-4a3a-89a5-9d1da7142a16} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:39.691596 [ 1436 ] {25fd32e4-4a8b-4a3a-89a5-9d1da7142a16} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-1-gh,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.696344 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-gh,: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.715853 [ 2303 ] {c856650e-48c6-4c9f-965d-6cfbe5c876ca} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) . (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:39.728545 [ 1436 ] {c856650e-48c6-4c9f-965d-6cfbe5c876ca} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:44866) (comment: 02916_date_text_parsing.sql) (in query: select * from format(CSV, 'd Date, s String', '2020-1-h,SomeString');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:39.733749 [ 1436 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 2020-1-h,S: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : While executing ParallelParsingBlockInputFormat. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./src/IO/ReadHelpers.h:758: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000138a9099 5. ./src/IO/ReadHelpers.h:806: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000138a8e7a 6. ./src/IO/ReadHelpers.h:846: void DB::readCSVSimple, void>(StrongTypedef&, DB::ReadBuffer&, DateLUTImpl const&) @ 0x00000000184ffd94 7. ./src/IO/ReadHelpers.h:1617: DB::SerializationDate::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x00000000184ffa8b 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:674: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000001856bd74 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:785: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000018569b39 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:395: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000001c65473d 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:262: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000001c610440 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000001c5d2ef0 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001c540955 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000001c50e2b5 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000001c50df8b 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:181: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000001c765477 17. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:109: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000001c76353c 18. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:295: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c766a38 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.538070 [ 4787 ] {6d6b473b-7a9b-4103-ba66-e9db2f464634} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: -- can't promote right table type SELECT * FROM (SELECT toUInt64(k) as k FROM t2) as t2 INNER JOIN rdb ON rdb.key == t2.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.546847 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.698394 [ 4787 ] {aeb5fdbd-3cce-4d0f-af35-19d49fbfbade} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.701322 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.712366 [ 4818 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af79ea 6. ./build_docker/./src/Server/TCPHandler.cpp:1776: DB::TCPHandler::receiveHello() @ 0x000000001c4117f4 7. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000001c40800f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:44.714446 [ 4818 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af79ea 6. ./build_docker/./src/Server/TCPHandler.cpp:1776: DB::TCPHandler::receiveHello() @ 0x000000001c4117f4 7. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000001c40800f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:44.785299 [ 4787 ] {6788e496-d4f5-455c-a95b-77abf2f0d3ee} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 FULL JOIN rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.787200 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.867914 [ 4787 ] {6c3ce579-fe26-42dc-8952-71f2700ed16e} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 INNER JOIN rdb ON rdb.key + 1 == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.872337 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.966991 [ 4787 ] {2ddbf240-b79a-41f9-b3c4-ce8753cd9fd8} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 INNER JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:44.973373 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:45.068019 [ 4787 ] {3bcab901-b871-42b4-b7ac-6508f33fb633} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT SEMI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:45.071603 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:45.090013 [ 4787 ] {9a10a0af-cf5f-41f5-9abd-c7ce8d231847} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:34674) (comment: 02242_join_rocksdb.sql) (in query: SELECT * FROM t1 RIGHT ANTI JOIN (SELECT * FROM rdb) AS rdb ON rdb.key == t1.k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:45.091239 [ 4787 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Planner/PlannerJoins.cpp:944: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x00000000199f1903 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1690: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cd259 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 7. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 8. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 12. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 13. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:45.106464 [ 4816 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af79ea 6. ./build_docker/./src/Server/TCPHandler.cpp:1776: DB::TCPHandler::receiveHello() @ 0x000000001c4117f4 7. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000001c40800f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:45.107138 [ 4816 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af79ea 6. ./build_docker/./src/Server/TCPHandler.cpp:1776: DB::TCPHandler::receiveHello() @ 0x000000001c4117f4 7. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000001c40800f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:45.408723 [ 4819 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:248: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001c445ac7 6. ./build_docker/./src/Server/HTTPHandler.cpp:213: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001c35a764 7. ./build_docker/./src/Server/HTTPHandler.cpp:229: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35ac72 8. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:45.432330 [ 4825 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./build_docker/./src/Access/AccessControl.cpp:628: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000017c55da1 4. ./build_docker/./src/Interpreters/Session.cpp:370: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000019af81e4 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:248: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000001c445ac7 6. ./build_docker/./src/Server/HTTPHandler.cpp:213: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001c35a764 7. ./build_docker/./src/Server/HTTPHandler.cpp:229: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001c35ac72 8. ./build_docker/./src/Server/HTTPHandler.cpp:751: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001c3637bb 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000001c438f3c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:48.539030 [ 4825 ] {412ea1b7-218a-46c7-bfc7-6d77a8d9c83a} executeQuery: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42492) (comment: 02271_fix_column_matcher_and_column_transformer.sql) (in query: EXPLAIN PIPELINE header = true, compact = true WITH top_repos AS (SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 WHERE (event_type = 'WatchEvent') AND (toMonday(created_at) = toMonday(today() - toIntervalWeek(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events__fuzz_0 PREWHERE (event_type = 'WatchEvent') AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count() DESC LIMIT 100 UNION DISTINCT SELECT repo_name FROM github_events WHERE (event_type = 'WatchEvent') AND (toYear(created_at) = (toYear(today()) - 1)) GROUP BY repo_name ORDER BY count() DESC LIMIT 100), last_day AS (SELECT repo_name, count() AS count_last_day, rowNumberInAllBlocks() + 1 AS position_last_day FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toDate(created_at) = (today() - 1)) GROUP BY repo_name ORDER BY count_last_day DESC), last_week AS (SELECT repo_name, count() AS count_last_week, rowNumberInAllBlocks() + 1 AS position_last_week FROM github_events WHERE (repo_name IN (SELECT repo_name FROM top_repos)) AND (toMonday(created_at) = (toMonday(today()) - toIntervalWeek(2))) GROUP BY repo_name ORDER BY count_last_week DESC), last_month AS (SELECT repo_name, count() AS count_last_month, rowNumberInAllBlocks() + 1 AS position_last_month FROM github_events__fuzz_0 WHERE ('deleted' = 4) AND in(repo_name) AND (toStartOfMonth(created_at) = (toStartOfMonth(today()) - toIntervalMonth(1))) GROUP BY repo_name ORDER BY count_last_month DESC) SELECT d.repo_name, COLUMNS(count) FROM last_day AS d INNER JOIN last_week AS w ON d.repo_name = w.repo_name INNER JOIN last_month AS m ON d.repo_name = m.repo_name format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x00000000179cfbc6 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:330: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000019503048 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:96: DB::InterpreterExplainQuery::execute() @ 0x00000000194fe0ff 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:48.546377 [ 4825 ] {} TCPHandler: Code: 471. DB::Exception: Invalid type Bool for setting "header" only integer settings are supported. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception>, String const&>(int, FormatStringHelperImpl>>::type, std::type_identity::type>, std::basic_string_view>&&, String const&) @ 0x00000000179cfbc6 4. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:330: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000019503048 5. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:96: DB::InterpreterExplainQuery::execute() @ 0x00000000194fe0ff 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 8. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:49.231649 [ 4876 ] {8c4e2f2a-0fd7-4a4f-abfd-133698244e15} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:42592). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:49.447141 [ 4876 ] {8c4e2f2a-0fd7-4a4f-abfd-133698244e15} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:42592). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42592) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:49.539409 [ 4876 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:42592). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c58eb 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.795719 [ 4866 ] {49bedec5-6fdf-41ac-af0b-0fa0c6ef96bb} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42564) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.795888 [ 4902 ] {728f264e-45a7-443e-a2c7-afb17dede5fc} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42646) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803725 [ 4893 ] {2251fef3-b079-4695-820f-8b7785e05d3f} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42600) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803739 [ 4858 ] {6fb1c8a1-3936-4860-9953-b262f12eb262} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42520) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803719 [ 4861 ] {9545c9a9-d72e-4e0b-99bd-00f9fda5e53d} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42532) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803821 [ 4906 ] {c8819d88-571d-47df-bf5e-a746be9828fc} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42688) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803839 [ 4896 ] {a2bdf1d4-0ee1-44d1-b975-30f7a891693e} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42614) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.803936 [ 4905 ] {0783e5d0-26bc-4ed5-91f3-0debe9ae8564} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42680) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.795846 [ 4898 ] {51e1e58e-86df-4c95-8d22-0f280146000f} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42638) (in query: SELECT * from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.902310 [ 4861 ] {9545c9a9-d72e-4e0b-99bd-00f9fda5e53d} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42532). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001c414795 7. ./build_docker/./src/Server/TCPHandler.cpp:829: DB::TCPHandler::runImpl() @ 0x000000001c409e8f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.903366 [ 4858 ] {6fb1c8a1-3936-4860-9953-b262f12eb262} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42520). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001c414795 7. ./build_docker/./src/Server/TCPHandler.cpp:829: DB::TCPHandler::runImpl() @ 0x000000001c409e8f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.903841 [ 4866 ] {49bedec5-6fdf-41ac-af0b-0fa0c6ef96bb} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42564). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001c414795 7. ./build_docker/./src/Server/TCPHandler.cpp:829: DB::TCPHandler::runImpl() @ 0x000000001c409e8f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.903856 [ 4905 ] {0783e5d0-26bc-4ed5-91f3-0debe9ae8564} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42680). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000001c414795 7. ./build_docker/./src/Server/TCPHandler.cpp:829: DB::TCPHandler::runImpl() @ 0x000000001c409e8f 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.910369 [ 4898 ] {51e1e58e-86df-4c95-8d22-0f280146000f} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42638). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000001c4281da 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000001c417a20 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000001c409dff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.910432 [ 4902 ] {728f264e-45a7-443e-a2c7-afb17dede5fc} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42646). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000001c4281da 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000001c417a20 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000001c409dff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.910446 [ 4893 ] {2251fef3-b079-4695-820f-8b7785e05d3f} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42600). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000001c4281da 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000001c417a20 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000001c409dff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.910376 [ 4896 ] {a2bdf1d4-0ee1-44d1-b975-30f7a891693e} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42614). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000001c4281da 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000001c417a20 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000001c409dff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.911958 [ 4906 ] {c8819d88-571d-47df-bf5e-a746be9828fc} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:42688). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2506: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000001c4281da 7. ./build_docker/./src/Server/TCPHandler.cpp:2594: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000001c417a20 8. ./build_docker/./src/Server/TCPHandler.cpp:816: DB::TCPHandler::runImpl() @ 0x000000001c409dff 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:42:50.914433 [ 4858 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.914796 [ 4861 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.917796 [ 4905 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.925274 [ 4896 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.925983 [ 4906 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.926052 [ 4902 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.926237 [ 4898 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.927025 [ 4893 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:50.935345 [ 4866 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: _ZN2DB12NetExceptionC2IRA53_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000001c42b8e6 3. ./build_docker/./src/Server/TCPHandler.cpp:2400: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000001c42417d 4. ./build_docker/./src/Server/TCPHandler.cpp:1236: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416d9e 5. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 6. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 12. __tsan_thread_start_func @ 0x0000000007b08428 13. ? @ 0x00007fd7c201fac3 14. ? @ 0x00007fd7c20b1850 2025.04.02 09:42:51.880943 [ 4941 ] {58636e25-9ba4-466f-a413-36e2084990aa} executeQuery: Code: 43. DB::Exception: Comparing aggregate functions with different types: AggregateFunction(groupBitmap, UInt8) and AggregateFunction(groupBitmap, UInt64): While processing bitmapHasAny(bitmapBuild([toUInt8(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt8)')) AS _subquery1) AS has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt64)')) AS _subquery2) AS has2. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:42724) (comment: 02677_analyzer_bitmap_has_any.sql) (in query: SELECT * FROM ( SELECT bitmapHasAny(bitmapBuild([toUInt8(1)]), ( SELECT groupBitmapState(toUInt8(1)) )) has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), ( SELECT groupBitmapState(toUInt64(2)) )) has2 ) SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000007b9f446 4. DB::AggregateFunctionStateData::operator==(DB::AggregateFunctionStateData const&) const @ 0x0000000008c19b37 5. DB::Field::operator==(DB::Field const&) const @ 0x0000000008c18f87 6. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1382: DB::ActionsMatcher::visit(DB::ASTLiteral const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f93e52 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:734: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a142 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:844: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f94779 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a155 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000018f7c74d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000018f4b36c 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000018f5baf3 19. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000018f63524 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000019949751 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001993d2ec 22. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001993662b 23. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019930fa6 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000019a18554 25. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019a16868 26. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:54: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000019a19660 27. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000019e41818 28. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000019a4873b 29. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:577: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000199324be 30. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019930fa6 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000019a18554 2025.04.02 09:42:51.884583 [ 4941 ] {} TCPHandler: Code: 43. DB::Exception: Comparing aggregate functions with different types: AggregateFunction(groupBitmap, UInt8) and AggregateFunction(groupBitmap, UInt64): While processing bitmapHasAny(bitmapBuild([toUInt8(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt8)')) AS _subquery1) AS has1, bitmapHasAny(bitmapBuild([toUInt64(1)]), __scalarSubqueryResult(_CAST('\0\0', 'AggregateFunction(groupBitmap, UInt64)')) AS _subquery2) AS has2. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000007b9f446 4. DB::AggregateFunctionStateData::operator==(DB::AggregateFunctionStateData const&) const @ 0x0000000008c19b37 5. DB::Field::operator==(DB::Field const&) const @ 0x0000000008c18f87 6. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1382: DB::ActionsMatcher::visit(DB::ASTLiteral const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f93e52 7. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:734: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a142 8. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 12. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1255: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8f0ce 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:732: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a054 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:844: DB::ActionsMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f94779 15. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:736: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000018f8a155 16. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000018f7c74d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000018f4b36c 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1588: DB::SelectQueryExpressionAnalyzer::appendSelect(DB::ExpressionActionsChain&, bool) @ 0x0000000018f5baf3 19. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2173: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000018f63524 20. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1172: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000019949751 21. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:911: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x000000001993d2ec 22. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:921: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001993662b 23. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019930fa6 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000019a18554 25. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:165: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019a16868 26. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:54: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000019a19660 27. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000019e41818 28. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000019a4873b 29. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:577: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000199324be 30. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:302: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019930fa6 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000019a18554 2025.04.02 09:43:02.137595 [ 4991 ] {dfe03f3e-04b0-45f9-8d02-456dee2288db} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT (1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000001420bd8c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x00000000171a53c9 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6403 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:02.145595 [ 4991 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000001420bd8c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x00000000171a53c9 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6403 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:02.383520 [ 4991 ] {2cfbccfc-8439-4ced-a710-af42f7b6d122} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT ((1,));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.387674 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.401344 [ 4991 ] {c81675f3-5d10-4eb4-aa8c-6fb6b6a319d1} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT tuple(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.407119 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8)) of argument of function not: In scope SELECT NOT tuple(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.521659 [ 4991 ] {314fb33e-fe27-46e5-9d8d-ea2d598bc182} executeQuery: Code: 43. DB::Exception: Illegal type (Tuple(UInt8, UInt8, UInt8)) of argument of function not: In scope SELECT NOT ((1, 1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT ((1, 1, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.522950 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Tuple(UInt8, UInt8, UInt8)) of argument of function not: In scope SELECT NOT ((1, 1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.659357 [ 4991 ] {91cdd349-07b1-4146-97a2-90b187813604} executeQuery: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT [1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.663133 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.679162 [ 4991 ] {cb84b1e4-a401-403c-ae36-0668603e28d1} executeQuery: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT NOT [(1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.683459 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(UInt8)) of argument of function not: In scope SELECT NOT [1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsLogicalDetail::FunctionUnaryLogical::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000017234143 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:02.991566 [ 4991 ] {8813239b-da01-47cf-9d84-6c2f43f7f7c6} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT -[1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d21650a 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d2086b6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 2025.04.02 09:43:02.996760 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d21650a 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d2086b6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 2025.04.02 09:43:03.008695 [ 4991 ] {a8a0be65-4d89-4a3d-a237-d459b0d244d8} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:45676) (comment: 03168_inconsistent_ast_formatting.sql) (in query: SELECT -[(1)];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d21650a 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d2086b6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 2025.04.02 09:43:03.011552 [ 4991 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of argument of function negate: In scope SELECT -[1]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionUnaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d21650a 5. DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d2086b6 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 25. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 26. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 2025.04.02 09:43:04.833960 [ 5024 ] {695bc5bb-a070-42e4-80cd-ff867b6a4fe8} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52392) (comment: 01634_uuid_fuzz.sql) (in query: SELECT toUUID(-1.1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./src/Functions/FunctionsConversion.h:1714: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeUUID, DB::detail::NameToUUID, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000175b564b 5. ./src/Functions/FunctionsConversion.h:2456: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000001745b6d0 6. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017487831 7. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017486cc0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:43:04.842886 [ 5024 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUUID(-1.1). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./src/Functions/FunctionsConversion.h:1714: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeUUID, DB::detail::NameToUUID, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000175b564b 5. ./src/Functions/FunctionsConversion.h:2456: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000001745b6d0 6. ./src/Functions/FunctionsConversion.h:2511: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017487831 7. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000017486cc0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:43:08.334712 [ 5032 ] {2fd47b90-111c-4d4e-a875-f9e2e09f9c49} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52424) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 25. __tsan_thread_start_func @ 0x0000000007b08428 26. ? @ 0x00007fd7c201fac3 27. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.327396 [ 5030 ] {9442202d-9d35-49cb-8744-f6067d0d5c16} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (106.667, 10.7674); method: t; operations: x/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 4}/{0, -1, -1, 0}: In scope SELECT pointInPolygon((106.677085876465, 10.7744951248169), [(106.667161868227, 10.7675128359024), (106.667165727127, 10.7675059912261), (106.667170817563, 10.7674904752629), (106.667229225265, 10.7672278502066), (106.667231193621, 10.7672115129572), (106.667229912029, 10.7671951075415), (106.667225430503, 10.767179274157), (106.667217923927, 10.7671646306786), (106.667207685234, 10.7671517485471), (106.667195113975, 10.7671411304688), (106.667180700725, 10.7671331907989), (106.66716500794, 10.7671282393715), (106.666628232995, 10.7670156787539), (106.666612233649, 10.7670139127584), (106.666596193354, 10.7670152569112), (106.666580711053, 10.7670196610218), (106.666566364856, 10.7670269606408), (106.666553690448, 10.7670368832008), (106.666543161092, 10.767049058194), (106.666535169952, 10.7670630310067), (106.666530015418, 10.7670782798948), (106.666482284259, 10.7672828714379), (106.666480170141, 10.7672985245675), (106.666481048788, 10.7673142953614), (106.666484888609, 10.7673296167758), (106.666491551541, 10.7673439379244), (106.666500798017, 10.7673567438858), (106.666512295576, 10.7673675742178), (106.666525630821, 10.7673760395122), (106.667032331859, 10.7676338521733), (106.6671413386, 10.7676893154858), (106.667371048786, 10.7678061934666), (106.667552760053, 10.7678987010209), (106.667801848625, 10.7680278028917), (106.667817742281, 10.7680340673957), (106.667834579682, 10.7680369577679), (106.66785165264, 10.7680363524383), (106.667868243061, 10.7680322768672), (106.667878683314, 10.7680285412847), (106.667885469819, 10.7680268413536), (106.667892390269, 10.7680258148018), (106.667899378015, 10.7680254715159), (106.667906365761, 10.7680258148018), (106.667913286211, 10.7680268413536), (106.667920072716, 10.7680285412847), (106.667926659921, 10.7680308982244), (106.667932984386, 10.7680338894736), (106.667938985204, 10.7680374862253), (106.667944604583, 10.7680416538412), (106.667949788405, 10.7680463521828), (106.667954486747, 10.7680515360051), (106.667958654362, 10.7680571553826), (106.667962251113, 10.7680631561994), (106.667965242363, 10.7680694806664), (106.667967599303, 10.7680760678724), (106.667969299234, 10.7680828543774), (106.667970926246, 10.7680938227996), (106.667974657027, 10.7681089916695), (106.667981154238, 10.7681231972879), (106.667990189396, 10.7681359400994), (106.668001444773, 10.7681467719897), (106.668014524559, 10.7681553120441), (106.668198488147, 10.7682521458591), (106.669562015793, 10.7689901124345), (106.669614757162, 10.7690820717448), (106.669623023723, 10.7690939566151), (106.669633223154, 10.7691042307472), (106.669645047385, 10.7691125838155), (106.670748051536, 10.7697559307954), (106.670751419717, 10.7697577924329), (106.671035494073, 10.7699063431327), (106.671270162713, 10.7700364834325), (106.67127192876, 10.7700374352053), (106.671437929267, 10.7701243344783), (106.671665917937, 10.7702517637461), (106.67166656035, 10.7702521191025), (106.671943689514, 10.7704038245574), (106.671943806749, 10.7704038886117), (106.6722776446, 10.7705859421916), (106.672278295949, 10.7705862936499), (106.673020324076, 10.7709824352208), (106.673433726727, 10.7712057751884), (106.673694081332, 10.7713489702214), (106.673977066657, 10.7715146655761), (106.674254247937, 10.7716778144336), (106.67440928634, 10.7717698954974), (106.674658478275, 10.7719268836667), (106.674658802254, 10.7719270867325), (106.6748919449, 10.7720724734391), (106.675071660589, 10.7721853602936), (106.675350447469, 10.7723606751059), (106.675350748696, 10.7723608636368), (106.6756252856, 10.7725318758852), (106.675888735092, 10.7726957126602), (106.676114500069, 10.7728361211927), (106.676379504941, 10.7730007692002), (106.67661713771, 10.7731502653527), (106.676617572241, 10.773150536857), (106.676852995814, 10.7732966297465), (106.677284352687, 10.7735807849214), (106.677738143311, 10.7738851794554), (106.677752655777, 10.7738929549383), (106.677768414072, 10.773897724206), (106.677784802596, 10.7738993009456), (106.677801181124, 10.7738976235612), (106.677816909825, 10.7738927575805), (106.677831374252, 10.7738848930944), (106.677844009349, 10.7738743373313), (106.677920079221, 10.7737967983562), (106.678239245717, 10.7735243703649), (106.67839926068, 10.7733892116467), (106.678400691571, 10.7733879749217), (106.678515896101, 10.7732860955802), (106.678557979259, 10.7732504310319), (106.67855930664, 10.7732492818517), (106.679033975331, 10.7728295048433), (106.679053201911, 10.772844898411), (106.679632133733, 10.7733262832973), (106.679771732358, 10.7734524450384), (106.679773325229, 10.7734538481348), (106.680011463819, 10.7736582857586), (106.680175801881, 10.7738018862846), (106.680176891116, 10.7738028216402), (106.680320149367, 10.773923712053), (106.680672123374, 10.7742204563391), (106.68094213423, 10.7744504786771), (106.68094233625, 10.7744506502241), (106.68124725775, 10.7747087432576), (106.681247329066, 10.7747088035527), (106.681470746982, 10.7748974804345), (106.681471338135, 10.7748979749973), (106.681840030697, 10.7752035373868), (106.682304929691, 10.7756040772245), (106.682308650112, 10.7756071005185), (106.682312917236, 10.7756103687835), (106.682359764439, 10.7756490693986), (106.682640114944, 10.7758996628849), (106.682644070655, 10.7759029839554), (106.682711710544, 10.7759562859055), (106.682806505954, 10.7760368956153), (106.68280745353, 10.776037689352), (106.683169164535, 10.7763361378178), (106.68363265876, 10.7767252395911), (106.683677875719, 10.7767650291442), (106.683797775698, 10.77688614766), (106.684138558845, 10.7772306328105), (106.68414063031, 10.7772326552454), (106.684827531639, 10.777880369263), (106.685228619785, 10.7782605077038), (106.685228896163, 10.7782607684525), (106.686025996525, 10.7790093622583), (106.686026813787, 10.7790101368229), (106.68658269265, 10.7795369738106), (106.687194479537, 10.7801158277128), (106.688401155505, 10.7812670656457), (106.688401571342, 10.7812674596561), (106.689622367701, 10.7824162362891), (106.690002723257, 10.7827815572149), (106.690002908997, 10.7827817350625), (106.690359062158, 10.7831217027417), (106.690359638585, 10.7831222477508), (106.690747557266, 10.7834855403784), (106.691628272565, 10.7843952548301), (106.692179613338, 10.7849709155958), (106.692179802225, 10.7849711121697), (106.692743910048, 10.7855562574979), (106.693288875836, 10.7861225208133), (106.693601234729, 10.7864484801726), (106.69220838651, 10.7875617536129), (106.692196691453, 10.787573150248), (106.692187444486, 10.7875866094924), (106.692181000965, 10.7876016141149), (106.692177608512, 10.7876175874962), (106.692177397496, 10.7876339157883), (106.692180376026, 10.7876499715041), (106.692186429639, 10.7876651376314), (106.692195325699, 10.7876788313445), (106.692206722334, 10.7876905264015), (106.692220181578, 10.7876997733682), (106.692235186201, 10.7877062168886), (106.692251159582, 10.787709609342), (106.692267487874, 10.7877098203582), (106.69228354359, 10.7877068418281), (106.692298709717, 10.7877007882148), (106.69231240343, 10.7876918921553), (106.693776442708, 10.7865217172423), (106.693788736175, 10.7865096022178), (106.693798269005, 10.7864952137411), (106.693804631934, 10.7864791695437), (106.693807551784, 10.7864621584413), (106.693806903199, 10.7864449107613), (106.693802714026, 10.7864281669878), (106.693795164114, 10.786412645971), (106.693784577601, 10.7863990140651), (106.69340910087, 10.7860071886444), (106.69340897739, 10.7860070600637), (106.692863924954, 10.7854407067139), (106.69229983717, 10.7848555821281), (106.691748435669, 10.7842798579551), (106.691748124777, 10.7842795350934), (106.690865834778, 10.7833681940925), (106.690862927107, 10.7833653342196), (106.690473809086, 10.7830009183885), (106.690118035849, 10.7826613133679), (106.689737465891, 10.7822957865149), (106.689736848623, 10.7822951996834), (106.688515950726, 10.7811463275029), (106.687309357068, 10.7799951680976), (106.687309106711, 10.779994930232), (106.686697270266, 10.7794160294802), (106.686141416688, 10.7788892164565), (106.686140461741, 10.7788883114), (106.686140185762, 10.7788880510296), (106.6853430856, 10.7781394574112), (106.684942058447, 10.7777593767781), (106.684941904463, 10.7777592312084), (106.684255979358, 10.7771124377212), (106.683916204215, 10.776768971525), (106.683794256559, 10.7766457845149), (106.68379008676, 10.7766418525893), (106.683741989497, 10.7765995284558), (106.683740519326, 10.7765982647987), (106.683276011394, 10.7762083120217), (106.683275466929, 10.7762078588774), (106.68291395946, 10.77590957835), (106.682818451152, 10.775828362424), (106.682816046951, 10.7758263940715), (106.682749215964, 10.7757737295564), (106.682469581984, 10.775523776542), (106.682467121137, 10.7755216616573), (106.682417839663, 10.775480950083), (106.68241543796, 10.7754790393628), (106.682411856108, 10.7754762959601), (106.681948170223, 10.775076801292), (106.681946953215, 10.7750757728772), (106.681577943952, 10.7747699480145), (106.681354856141, 10.7745815499075), (106.681050071432, 10.7743235726569), (106.680779998801, 10.774093497693), (106.680779672798, 10.7740932214111), (106.680427578845, 10.7737963760106), (106.680284883706, 10.7736759607876), (106.680120811518, 10.7735325925854), (106.680120259999, 10.7735321149047), (106.679882649978, 10.7733281310479), (106.679742564868, 10.7732015296478), (106.67973997054, 10.7731992804165), (106.679159125009, 10.772716304271), (106.679157929246, 10.7727153285815), (106.679083371982, 10.7726556350576), (106.679069423592, 10.7726465921904), (106.679053957365, 10.7726404990091), (106.679037589221, 10.7726375981655), (106.679020970997, 10.7726380051815), (106.679004764489, 10.7726417038483), (106.678989615098, 10.7726485468719), (106.678976126125, 10.772658261739), (106.678449597495, 10.7731239014943), (106.678407514754, 10.773159565689), (106.678406188192, 10.7731607141448), (106.678291034854, 10.7732625482153), (106.678131577851, 10.7733972356454), (106.678131249559, 10.7733975143985), (106.677809116892, 10.7736724741964), (106.677803734254, 10.7736774962862), (106.67777351642, 10.773708297704), (106.677376870851, 10.7734422350384), (106.677376291861, 10.7734418501559), (106.676943701895, 10.7731568826838), (106.676941799819, 10.7731556663352), (106.676705634648, 10.7730091132449), (106.676468020922, 10.7728596290723), (106.676467624617, 10.7728593813034), (106.676202468827, 10.7726946395397), (106.675976718772, 10.7725542402878), (106.675713344944, 10.7723904505946), (106.675438984881, 10.7722195485022), (106.675160330528, 10.7720443170291), (106.674980445983, 10.7719313240966), (106.674980215342, 10.7719311797465), (106.674747119479, 10.7717858222138), (106.674497164595, 10.7716283533947), (106.674495300219, 10.7716272127471), (106.674339180867, 10.7715344896819), (106.674338897981, 10.771534322423), (106.674061493048, 10.7713710419232), (106.674061328848, 10.7713709455279), (106.673777295695, 10.7712046366425), (106.673775349509, 10.7712035319333), (106.673513740027, 10.7710596467179), (106.673513190173, 10.7710593469847), (106.673099330442, 10.7708357600807), (106.673098966779, 10.7708355647753), (106.672357083034, 10.7704395002842), (106.672023628724, 10.7702576558632), (106.671746880137, 10.7701061587426), (106.671518215262, 10.7699783515251), (106.671516207112, 10.7699772649622), (106.671350083838, 10.7698903014222), (106.671115399209, 10.7697601522552), (106.671113600766, 10.7697591835329), (106.670830326847, 10.7696110514048), (106.66974820551, 10.7689798847013), (106.66969475177, 10.7688866833063), (106.669685913661, 10.7688741199651), (106.669674918986, 10.7688633930448), (106.669662141606, 10.7688548673033), (106.668277363011, 10.7681053993183), (106.668276514094, 10.7681049461882), (106.668126503268, 10.7680259842551), (106.668125839186, 10.7680237950692), (106.66812072496, 10.7680095017658), (106.668117596648, 10.7680019493532), (106.66811110606, 10.7679882261576), (106.668107252546, 10.7679810167398), (106.668099448104, 10.7679679958141), (106.668094906497, 10.767961198818), (106.668085863361, 10.7679490055608), (106.668080677403, 10.7679426864524), (106.668070482664, 10.7679314382913), (106.668064702296, 10.7679256579236), (106.668053454135, 10.7679154631847), (106.668047135024, 10.7679102772246), (106.668034941766, 10.7679012340887), (106.668028144776, 10.7678966924853), (106.668015123851, 10.7678888880428), (106.668007914429, 10.7678850345264), (106.667994191233, 10.7678785439383), (106.667986638821, 10.7678754156266), (106.667972345518, 10.7678703014008), (106.667964522841, 10.7678679284177), (106.667949797082, 10.7678642398071), (106.667941779481, 10.7678626450072), (106.667926763083, 10.767860417535), (106.667918627772, 10.7678596162768), (106.667903465352, 10.7678588713949), (106.667895290678, 10.7678588713949), (106.667880128258, 10.7678596162768), (106.667871992947, 10.767860417535), (106.667856976549, 10.7678626450072), (106.667848958948, 10.7678642398071), (106.667848526162, 10.7678643482145), (106.667629153721, 10.7677506481269), (106.667628614008, 10.7677503708842), (106.66744662399, 10.7676577214203), (106.667216888626, 10.7675408306262), (106.667161868227, 10.7675128359024), (106.667012119458, 10.7674366427911), (106.666659357657, 10.7672571553777), (106.666673753979, 10.7671954479766), (106.667048293768, 10.7672739882109), (106.667012119458, 10.7674366427911)]). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52410) (comment: 00500_point_in_polygon_bug_3_linestring_rotation_precision.sql) (in query: SELECT pointInPolygon((106.677085876465,10.7744951248169), [(106.667161868227,10.7675128359024),(106.667165727127,10.7675059912261),(106.667170817563,10.7674904752629),(106.667229225265,10.7672278502066),(106.667231193621,10.7672115129572),(106.667229912029,10.7671951075415),(106.667225430503,10.767179274157),(106.667217923927,10.7671646306786),(106.667207685234,10.7671517485471),(106.667195113975,10.7671411304688),(106.667180700725,10.7671331907989),(106.66716500794,10.7671282393715),(106.666628232995,10.7670156787539),(106.666612233649,10.7670139127584),(106.666596193354,10.7670152569112),(106.666580711053,10.7670196610218),(106.666566364856,10.7670269606408),(106.666553690448,10.7670368832008),(106.666543161092,10.767049058194),(106.666535169952,10.7670630310067),(106.666530015418,10.7670782798948),(106.666482284259,10.7672828714379),(106.666480170141,10.7672985245675),(106.666481048788,10.7673142953614),(106.666484888609,10.7673296167758),(106.666491551541,10.7673439379244),(106.666500798017,10.7673567438858),(106.666512295576,10.7673675742178),(106.666525630821,10.7673760395122),(106.667032331859,10.7676338521733),(106.6671413386,10.7676893154858),(106.667371048786,10.7678061934666),(106.667552760053,10.7678987010209),(106.667801848625,10.7680278028917),(106.667817742281,10.7680340673957),(106.667834579682,10.7680369577679),(106.66785165264,10.7680363524383),(106.667868243061,10.7680322768672),(106.667878683314,10.7680285412847),(106.667885469819,10.7680268413536),(106.667892390269,10.7680258148018),(106.667899378015,10.7680254715159),(106.667906365761,10.7680258148018),(106.667913286211,10.7680268413536),(106.667920072716,10.7680285412847),(106.667926659921,10.7680308982244),(106.667932984386,10.7680338894736),(106.667938985204,10.7680374862253),(106.667944604583,10.7680416538412),(106.667949788405,10.7680463521828),(106.667954486747,10.7680515360051),(106.667958654362,10.7680571553826),(106.667962251113,10.7680631561994),(106.667965242363,10.7680694806664),(106.667967599303,10.7680760678724),(106.667969299234,10.7680828543774),(106.667970926246,10.7680938227996),(106.667974657027,10.7681089916695),(106.667981154238,10.7681231972879),(106.667990189396,10.7681359400994),(106.668001444773,10.7681467719897),(106.668014524559,10.7681553120441),(106.668198488147,10.7682521458591),(106.669562015793,10.7689901124345),(106.669614757162,10.7690820717448),(106.669623023723,10.7690939566151),(106.669633223154,10.7691042307472),(106.669645047385,10.7691125838155),(106.670748051536,10.7697559307954),(106.670751419717,10.7697577924329),(106.671035494073,10.7699063431327),(106.671270162713,10.7700364834325),(106.67127192876,10.7700374352053),(106.671437929267,10.7701243344783),(106.671665917937,10.7702517637461),(106.67166656035,10.7702521191025),(106.671943689514,10.7704038245574),(106.671943806749,10.7704038886117),(106.6722776446,10.7705859421916),(106.672278295949,10.7705862936499),(106.673020324076,10.7709824352208),(106.673433726727,10.7712057751884),(106.673694081332,10.7713489702214),(106.673977066657,10.7715146655761),(106.674254247937,10.7716778144336),(106.67440928634,10.7717698954974),(106.674658478275,10.7719268836667),(106.674658802254,10.7719270867325),(106.6748919449,10.7720724734391),(106.675071660589,10.7721853602936),(106.675350447469,10.7723606751059),(106.675350748696,10.7723608636368),(106.6756252856,10.7725318758852),(106.675888735092,10.7726957126602),(106.676114500069,10.7728361211927),(106.676379504941,10.7730007692002),(106.67661713771,10.7731502653527),(106.676617572241,10.773150536857),(106.676852995814,10.7732966297465),(106.677284352687,10.7735807849214),(106.677738143311,10.7738851794554),(106.677752655777,10.7738929549383),(106.677768414072,10.773897724206),(106.677784802596,10.7738993009456),(106.677801181124,10.7738976235612),(106.677816909825,10.7738927575805),(106.677831374252,10.7738848930944),(106.677844009349,10.7738743373313),(106.677920079221,10.7737967983562),(106.678239245717,10.7735243703649),(106.67839926068,10.7733892116467),(106.678400691571,10.7733879749217),(106.678515896101,10.7732860955802),(106.678557979259,10.7732504310319),(106.67855930664,10.7732492818517),(106.679033975331,10.7728295048433),(106.679053201911,10.772844898411),(106.679632133733,10.7733262832973),(106.679771732358,10.7734524450384),(106.679773325229,10.7734538481348),(106.680011463819,10.7736582857586),(106.680175801881,10.7738018862846),(106.680176891116,10.7738028216402),(106.680320149367,10.773923712053),(106.680672123374,10.7742204563391),(106.68094213423,10.7744504786771),(106.68094233625,10.7744506502241),(106.68124725775,10.7747087432576),(106.681247329066,10.7747088035527),(106.681470746982,10.7748974804345),(106.681471338135,10.7748979749973),(106.681840030697,10.7752035373868),(106.682304929691,10.7756040772245),(106.682308650112,10.7756071005185),(106.682312917236,10.7756103687835),(106.682359764439,10.7756490693986),(106.682640114944,10.7758996628849),(106.682644070655,10.7759029839554),(106.682711710544,10.7759562859055),(106.682806505954,10.7760368956153),(106.68280745353,10.776037689352),(106.683169164535,10.7763361378178),(106.68363265876,10.7767252395911),(106.683677875719,10.7767650291442),(106.683797775698,10.77688614766),(106.684138558845,10.7772306328105),(106.68414063031,10.7772326552454),(106.684827531639,10.777880369263),(106.685228619785,10.7782605077038),(106.685228896163,10.7782607684525),(106.686025996525,10.7790093622583),(106.686026813787,10.7790101368229),(106.68658269265,10.7795369738106),(106.687194479537,10.7801158277128),(106.688401155505,10.7812670656457),(106.688401571342,10.7812674596561),(106.689622367701,10.7824162362891),(106.690002723257,10.7827815572149),(106.690002908997,10.7827817350625),(106.690359062158,10.7831217027417),(106.690359638585,10.7831222477508),(106.690747557266,10.7834855403784),(106.691628272565,10.7843952548301),(106.692179613338,10.7849709155958),(106.692179802225,10.7849711121697),(106.692743910048,10.7855562574979),(106.693288875836,10.7861225208133),(106.693601234729,10.7864484801726),(106.69220838651,10.7875617536129),(106.692196691453,10.787573150248),(106.692187444486,10.7875866094924),(106.692181000965,10.7876016141149),(106.692177608512,10.7876175874962),(106.692177397496,10.7876339157883),(106.692180376026,10.7876499715041),(106.692186429639,10.7876651376314),(106.692195325699,10.7876788313445),(106.692206722334,10.7876905264015),(106.692220181578,10.7876997733682),(106.692235186201,10.7877062168886),(106.692251159582,10.787709609342),(106.692267487874,10.7877098203582),(106.69228354359,10.7877068418281),(106.692298709717,10.7877007882148),(106.69231240343,10.7876918921553),(106.693776442708,10.7865217172423),(106.693788736175,10.7865096022178),(106.693798269005,10.7864952137411),(106.693804631934,10.7864791695437),(106.693807551784,10.7864621584413),(106.693806903199,10.7864449107613),(106.693802714026,10.7864281669878),(106.693795164114,10.786412645971),(106.693784577601,10.7863990140651),(106.69340910087,10.7860071886444),(106.69340897739,10.7860070600637),(106.692863924954,10.7854407067139),(106.69229983717,10.7848555821281),(106.691748435669,10.7842798579551),(106.691748124777,10.7842795350934),(106.690865834778,10.7833681940925),(106.690862927107,10.7833653342196),(106.690473809086,10.7830009183885),(106.690118035849,10.7826613133679),(106.689737465891,10.7822957865149),(106.689736848623,10.7822951996834),(106.688515950726,10.7811463275029),(106.687309357068,10.7799951680976),(106.687309106711,10.779994930232),(106.686697270266,10.7794160294802),(106.686141416688,10.7788892164565),(106.686140461741,10.7788883114),(106.686140185762,10.7788880510296),(106.6853430856,10.7781394574112),(106.684942058447,10.7777593767781),(106.684941904463,10.7777592312084),(106.684255979358,10.7771124377212),(106.683916204215,10.776768971525),(106.683794256559,10.7766457845149),(106.68379008676,10.7766418525893),(106.683741989497,10.7765995284558),(106.683740519326,10.7765982647987),(106.683276011394,10.7762083120217),(106.683275466929,10.7762078588774),(106.68291395946,10.77590957835),(106.682818451152,10.775828362424),(106.682816046951,10.7758263940715),(106.682749215964,10.7757737295564),(106.682469581984,10.775523776542),(106.682467121137,10.7755216616573),(106.682417839663,10.775480950083),(106.68241543796,10.7754790393628),(106.682411856108,10.7754762959601),(106.681948170223,10.775076801292),(106.681946953215,10.7750757728772),(106.681577943952,10.7747699480145),(106.681354856141,10.7745815499075),(106.681050071432,10.7743235726569),(106.680779998801,10.774093497693),(106.680779672798,10.7740932214111),(106.680427578845,10.7737963760106),(106.680284883706,10.7736759607876),(106.680120811518,10.7735325925854),(106.680120259999,10.7735321149047),(106.679882649978,10.7733281310479),(106.679742564868,10.7732015296478),(106.67973997054,10.7731992804165),(106.679159125009,10.772716304271),(106.679157929246,10.7727153285815),(106.679083371982,10.7726556350576),(106.679069423592,10.7726465921904),(106.679053957365,10.7726404990091),(106.679037589221,10.7726375981655),(106.679020970997,10.7726380051815),(106.679004764489,10.7726417038483),(106.678989615098,10.7726485468719),(106.678976126125,10.772658261739),(106.678449597495,10.7731239014943),(106.678407514754,10.773159565689),(106.678406188192,10.7731607141448),(106.678291034854,10.7732625482153),(106.678131577851,10.7733972356454),(106.678131249559,10.7733975143985),(106.677809116892,10.7736724741964),(106.677803734254,10.7736774962862),(106.67777351642,10.773708297704),(106.677376870851,10.7734422350384),(106.677376291861,10.7734418501559),(106.676943701895,10.7731568826838),(106.676941799819,10.7731556663352),(106.676705634648,10.7730091132449),(106.676468020922,10.7728596290723),(106.676467624617,10.7728593813034),(106.676202468827,10.7726946395397),(106.675976718772,10.7725542402878),(106.675713344944,10.7723904505946),(106.675438984881,10.7722195485022),(106.675160330528,10.7720443170291),(106.674980445983,10.7719313240966),(106.674980215342,10.7719311797465),(106.674747119479,10.7717858222138),(106.674497164595,10.7716283533947),(106.674495300219,10.7716272127471),(106.674339180867,10.7715344896819),(106.674338897981,10.771534322423),(106.674061493048,10.7713710419232),(106.674061328848,10.7713709455279),(106.673777295695,10.7712046366425),(106.673775349509,10.7712035319333),(106.673513740027,10.7710596467179),(106.673513190173,10.7710593469847),(106.673099330442,10.7708357600807),(106.673098966779,10.7708355647753),(106.672357083034,10.7704395002842),(106.672023628724,10.7702576558632),(106.671746880137,10.7701061587426),(106.671518215262,10.7699783515251),(106.671516207112,10.7699772649622),(106.671350083838,10.7698903014222),(106.671115399209,10.7697601522552),(106.671113600766,10.7697591835329),(106.670830326847,10.7696110514048),(106.66974820551,10.7689798847013),(106.66969475177,10.7688866833063),(106.669685913661,10.7688741199651),(106.669674918986,10.7688633930448),(106.669662141606,10.7688548673033),(106.668277363011,10.7681053993183),(106.668276514094,10.7681049461882),(106.668126503268,10.7680259842551),(106.668125839186,10.7680237950692),(106.66812072496,10.7680095017658),(106.668117596648,10.7680019493532),(106.66811110606,10.7679882261576),(106.668107252546,10.7679810167398),(106.668099448104,10.7679679958141),(106.668094906497,10.767961198818),(106.668085863361,10.7679490055608),(106.668080677403,10.7679426864524),(106.668070482664,10.7679314382913),(106.668064702296,10.7679256579236),(106.668053454135,10.7679154631847),(106.668047135024,10.7679102772246),(106.668034941766,10.7679012340887),(106.668028144776,10.7678966924853),(106.668015123851,10.7678888880428),(106.668007914429,10.7678850345264),(106.667994191233,10.7678785439383),(106.667986638821,10.7678754156266),(106.667972345518,10.7678703014008),(106.667964522841,10.7678679284177),(106.667949797082,10.7678642398071),(106.667941779481,10.7678626450072),(106.667926763083,10.767860417535),(106.667918627772,10.7678596162768),(106.667903465352,10.7678588713949),(106.667895290678,10.7678588713949),(106.667880128258,10.7678596162768),(106.667871992947,10.767860417535),(106.667856976549,10.7678626450072),(106.667848958948,10.7678642398071),(106.667848526162,10.7678643482145),(106.667629153721,10.7677506481269),(106.667628614008,10.7677503708842),(106.66744662399,10.7676577214203),(106.667216888626,10.7675408306262),(106.667161868227,10.7675128359024),(106.667012119458,10.7674366427911),(106.666659357657,10.7672571553777),(106.666673753979,10.7671954479766),(106.667048293768,10.7672739882109),(106.667012119458,10.7674366427911)] );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007bb9200 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da98772 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:08.352536 [ 5032 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 25. __tsan_thread_start_func @ 0x0000000007b08428 26. ? @ 0x00007fd7c201fac3 27. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.397877 [ 5030 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (106.667, 10.7674); method: t; operations: x/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 4}/{0, -1, -1, 0}: In scope SELECT pointInPolygon((106.677085876465, 10.7744951248169), [(106.667161868227, 10.7675128359024), (106.667165727127, 10.7675059912261), (106.667170817563, 10.7674904752629), (106.667229225265, 10.7672278502066), (106.667231193621, 10.7672115129572), (106.667229912029, 10.7671951075415), (106.667225430503, 10.767179274157), (106.667217923927, 10.7671646306786), (106.667207685234, 10.7671517485471), (106.667195113975, 10.7671411304688), (106.667180700725, 10.7671331907989), (106.66716500794, 10.7671282393715), (106.666628232995, 10.7670156787539), (106.666612233649, 10.7670139127584), (106.666596193354, 10.7670152569112), (106.666580711053, 10.7670196610218), (106.666566364856, 10.7670269606408), (106.666553690448, 10.7670368832008), (106.666543161092, 10.767049058194), (106.666535169952, 10.7670630310067), (106.666530015418, 10.7670782798948), (106.666482284259, 10.7672828714379), (106.666480170141, 10.7672985245675), (106.666481048788, 10.7673142953614), (106.666484888609, 10.7673296167758), (106.666491551541, 10.7673439379244), (106.666500798017, 10.7673567438858), (106.666512295576, 10.7673675742178), (106.666525630821, 10.7673760395122), (106.667032331859, 10.7676338521733), (106.6671413386, 10.7676893154858), (106.667371048786, 10.7678061934666), (106.667552760053, 10.7678987010209), (106.667801848625, 10.7680278028917), (106.667817742281, 10.7680340673957), (106.667834579682, 10.7680369577679), (106.66785165264, 10.7680363524383), (106.667868243061, 10.7680322768672), (106.667878683314, 10.7680285412847), (106.667885469819, 10.7680268413536), (106.667892390269, 10.7680258148018), (106.667899378015, 10.7680254715159), (106.667906365761, 10.7680258148018), (106.667913286211, 10.7680268413536), (106.667920072716, 10.7680285412847), (106.667926659921, 10.7680308982244), (106.667932984386, 10.7680338894736), (106.667938985204, 10.7680374862253), (106.667944604583, 10.7680416538412), (106.667949788405, 10.7680463521828), (106.667954486747, 10.7680515360051), (106.667958654362, 10.7680571553826), (106.667962251113, 10.7680631561994), (106.667965242363, 10.7680694806664), (106.667967599303, 10.7680760678724), (106.667969299234, 10.7680828543774), (106.667970926246, 10.7680938227996), (106.667974657027, 10.7681089916695), (106.667981154238, 10.7681231972879), (106.667990189396, 10.7681359400994), (106.668001444773, 10.7681467719897), (106.668014524559, 10.7681553120441), (106.668198488147, 10.7682521458591), (106.669562015793, 10.7689901124345), (106.669614757162, 10.7690820717448), (106.669623023723, 10.7690939566151), (106.669633223154, 10.7691042307472), (106.669645047385, 10.7691125838155), (106.670748051536, 10.7697559307954), (106.670751419717, 10.7697577924329), (106.671035494073, 10.7699063431327), (106.671270162713, 10.7700364834325), (106.67127192876, 10.7700374352053), (106.671437929267, 10.7701243344783), (106.671665917937, 10.7702517637461), (106.67166656035, 10.7702521191025), (106.671943689514, 10.7704038245574), (106.671943806749, 10.7704038886117), (106.6722776446, 10.7705859421916), (106.672278295949, 10.7705862936499), (106.673020324076, 10.7709824352208), (106.673433726727, 10.7712057751884), (106.673694081332, 10.7713489702214), (106.673977066657, 10.7715146655761), (106.674254247937, 10.7716778144336), (106.67440928634, 10.7717698954974), (106.674658478275, 10.7719268836667), (106.674658802254, 10.7719270867325), (106.6748919449, 10.7720724734391), (106.675071660589, 10.7721853602936), (106.675350447469, 10.7723606751059), (106.675350748696, 10.7723608636368), (106.6756252856, 10.7725318758852), (106.675888735092, 10.7726957126602), (106.676114500069, 10.7728361211927), (106.676379504941, 10.7730007692002), (106.67661713771, 10.7731502653527), (106.676617572241, 10.773150536857), (106.676852995814, 10.7732966297465), (106.677284352687, 10.7735807849214), (106.677738143311, 10.7738851794554), (106.677752655777, 10.7738929549383), (106.677768414072, 10.773897724206), (106.677784802596, 10.7738993009456), (106.677801181124, 10.7738976235612), (106.677816909825, 10.7738927575805), (106.677831374252, 10.7738848930944), (106.677844009349, 10.7738743373313), (106.677920079221, 10.7737967983562), (106.678239245717, 10.7735243703649), (106.67839926068, 10.7733892116467), (106.678400691571, 10.7733879749217), (106.678515896101, 10.7732860955802), (106.678557979259, 10.7732504310319), (106.67855930664, 10.7732492818517), (106.679033975331, 10.7728295048433), (106.679053201911, 10.772844898411), (106.679632133733, 10.7733262832973), (106.679771732358, 10.7734524450384), (106.679773325229, 10.7734538481348), (106.680011463819, 10.7736582857586), (106.680175801881, 10.7738018862846), (106.680176891116, 10.7738028216402), (106.680320149367, 10.773923712053), (106.680672123374, 10.7742204563391), (106.68094213423, 10.7744504786771), (106.68094233625, 10.7744506502241), (106.68124725775, 10.7747087432576), (106.681247329066, 10.7747088035527), (106.681470746982, 10.7748974804345), (106.681471338135, 10.7748979749973), (106.681840030697, 10.7752035373868), (106.682304929691, 10.7756040772245), (106.682308650112, 10.7756071005185), (106.682312917236, 10.7756103687835), (106.682359764439, 10.7756490693986), (106.682640114944, 10.7758996628849), (106.682644070655, 10.7759029839554), (106.682711710544, 10.7759562859055), (106.682806505954, 10.7760368956153), (106.68280745353, 10.776037689352), (106.683169164535, 10.7763361378178), (106.68363265876, 10.7767252395911), (106.683677875719, 10.7767650291442), (106.683797775698, 10.77688614766), (106.684138558845, 10.7772306328105), (106.68414063031, 10.7772326552454), (106.684827531639, 10.777880369263), (106.685228619785, 10.7782605077038), (106.685228896163, 10.7782607684525), (106.686025996525, 10.7790093622583), (106.686026813787, 10.7790101368229), (106.68658269265, 10.7795369738106), (106.687194479537, 10.7801158277128), (106.688401155505, 10.7812670656457), (106.688401571342, 10.7812674596561), (106.689622367701, 10.7824162362891), (106.690002723257, 10.7827815572149), (106.690002908997, 10.7827817350625), (106.690359062158, 10.7831217027417), (106.690359638585, 10.7831222477508), (106.690747557266, 10.7834855403784), (106.691628272565, 10.7843952548301), (106.692179613338, 10.7849709155958), (106.692179802225, 10.7849711121697), (106.692743910048, 10.7855562574979), (106.693288875836, 10.7861225208133), (106.693601234729, 10.7864484801726), (106.69220838651, 10.7875617536129), (106.692196691453, 10.787573150248), (106.692187444486, 10.7875866094924), (106.692181000965, 10.7876016141149), (106.692177608512, 10.7876175874962), (106.692177397496, 10.7876339157883), (106.692180376026, 10.7876499715041), (106.692186429639, 10.7876651376314), (106.692195325699, 10.7876788313445), (106.692206722334, 10.7876905264015), (106.692220181578, 10.7876997733682), (106.692235186201, 10.7877062168886), (106.692251159582, 10.787709609342), (106.692267487874, 10.7877098203582), (106.69228354359, 10.7877068418281), (106.692298709717, 10.7877007882148), (106.69231240343, 10.7876918921553), (106.693776442708, 10.7865217172423), (106.693788736175, 10.7865096022178), (106.693798269005, 10.7864952137411), (106.693804631934, 10.7864791695437), (106.693807551784, 10.7864621584413), (106.693806903199, 10.7864449107613), (106.693802714026, 10.7864281669878), (106.693795164114, 10.786412645971), (106.693784577601, 10.7863990140651), (106.69340910087, 10.7860071886444), (106.69340897739, 10.7860070600637), (106.692863924954, 10.7854407067139), (106.69229983717, 10.7848555821281), (106.691748435669, 10.7842798579551), (106.691748124777, 10.7842795350934), (106.690865834778, 10.7833681940925), (106.690862927107, 10.7833653342196), (106.690473809086, 10.7830009183885), (106.690118035849, 10.7826613133679), (106.689737465891, 10.7822957865149), (106.689736848623, 10.7822951996834), (106.688515950726, 10.7811463275029), (106.687309357068, 10.7799951680976), (106.687309106711, 10.779994930232), (106.686697270266, 10.7794160294802), (106.686141416688, 10.7788892164565), (106.686140461741, 10.7788883114), (106.686140185762, 10.7788880510296), (106.6853430856, 10.7781394574112), (106.684942058447, 10.7777593767781), (106.684941904463, 10.7777592312084), (106.684255979358, 10.7771124377212), (106.683916204215, 10.776768971525), (106.683794256559, 10.7766457845149), (106.68379008676, 10.7766418525893), (106.683741989497, 10.7765995284558), (106.683740519326, 10.7765982647987), (106.683276011394, 10.7762083120217), (106.683275466929, 10.7762078588774), (106.68291395946, 10.77590957835), (106.682818451152, 10.775828362424), (106.682816046951, 10.7758263940715), (106.682749215964, 10.7757737295564), (106.682469581984, 10.775523776542), (106.682467121137, 10.7755216616573), (106.682417839663, 10.775480950083), (106.68241543796, 10.7754790393628), (106.682411856108, 10.7754762959601), (106.681948170223, 10.775076801292), (106.681946953215, 10.7750757728772), (106.681577943952, 10.7747699480145), (106.681354856141, 10.7745815499075), (106.681050071432, 10.7743235726569), (106.680779998801, 10.774093497693), (106.680779672798, 10.7740932214111), (106.680427578845, 10.7737963760106), (106.680284883706, 10.7736759607876), (106.680120811518, 10.7735325925854), (106.680120259999, 10.7735321149047), (106.679882649978, 10.7733281310479), (106.679742564868, 10.7732015296478), (106.67973997054, 10.7731992804165), (106.679159125009, 10.772716304271), (106.679157929246, 10.7727153285815), (106.679083371982, 10.7726556350576), (106.679069423592, 10.7726465921904), (106.679053957365, 10.7726404990091), (106.679037589221, 10.7726375981655), (106.679020970997, 10.7726380051815), (106.679004764489, 10.7726417038483), (106.678989615098, 10.7726485468719), (106.678976126125, 10.772658261739), (106.678449597495, 10.7731239014943), (106.678407514754, 10.773159565689), (106.678406188192, 10.7731607141448), (106.678291034854, 10.7732625482153), (106.678131577851, 10.7733972356454), (106.678131249559, 10.7733975143985), (106.677809116892, 10.7736724741964), (106.677803734254, 10.7736774962862), (106.67777351642, 10.773708297704), (106.677376870851, 10.7734422350384), (106.677376291861, 10.7734418501559), (106.676943701895, 10.7731568826838), (106.676941799819, 10.7731556663352), (106.676705634648, 10.7730091132449), (106.676468020922, 10.7728596290723), (106.676467624617, 10.7728593813034), (106.676202468827, 10.7726946395397), (106.675976718772, 10.7725542402878), (106.675713344944, 10.7723904505946), (106.675438984881, 10.7722195485022), (106.675160330528, 10.7720443170291), (106.674980445983, 10.7719313240966), (106.674980215342, 10.7719311797465), (106.674747119479, 10.7717858222138), (106.674497164595, 10.7716283533947), (106.674495300219, 10.7716272127471), (106.674339180867, 10.7715344896819), (106.674338897981, 10.771534322423), (106.674061493048, 10.7713710419232), (106.674061328848, 10.7713709455279), (106.673777295695, 10.7712046366425), (106.673775349509, 10.7712035319333), (106.673513740027, 10.7710596467179), (106.673513190173, 10.7710593469847), (106.673099330442, 10.7708357600807), (106.673098966779, 10.7708355647753), (106.672357083034, 10.7704395002842), (106.672023628724, 10.7702576558632), (106.671746880137, 10.7701061587426), (106.671518215262, 10.7699783515251), (106.671516207112, 10.7699772649622), (106.671350083838, 10.7698903014222), (106.671115399209, 10.7697601522552), (106.671113600766, 10.7697591835329), (106.670830326847, 10.7696110514048), (106.66974820551, 10.7689798847013), (106.66969475177, 10.7688866833063), (106.669685913661, 10.7688741199651), (106.669674918986, 10.7688633930448), (106.669662141606, 10.7688548673033), (106.668277363011, 10.7681053993183), (106.668276514094, 10.7681049461882), (106.668126503268, 10.7680259842551), (106.668125839186, 10.7680237950692), (106.66812072496, 10.7680095017658), (106.668117596648, 10.7680019493532), (106.66811110606, 10.7679882261576), (106.668107252546, 10.7679810167398), (106.668099448104, 10.7679679958141), (106.668094906497, 10.767961198818), (106.668085863361, 10.7679490055608), (106.668080677403, 10.7679426864524), (106.668070482664, 10.7679314382913), (106.668064702296, 10.7679256579236), (106.668053454135, 10.7679154631847), (106.668047135024, 10.7679102772246), (106.668034941766, 10.7679012340887), (106.668028144776, 10.7678966924853), (106.668015123851, 10.7678888880428), (106.668007914429, 10.7678850345264), (106.667994191233, 10.7678785439383), (106.667986638821, 10.7678754156266), (106.667972345518, 10.7678703014008), (106.667964522841, 10.7678679284177), (106.667949797082, 10.7678642398071), (106.667941779481, 10.7678626450072), (106.667926763083, 10.767860417535), (106.667918627772, 10.7678596162768), (106.667903465352, 10.7678588713949), (106.667895290678, 10.7678588713949), (106.667880128258, 10.7678596162768), (106.667871992947, 10.767860417535), (106.667856976549, 10.7678626450072), (106.667848958948, 10.7678642398071), (106.667848526162, 10.7678643482145), (106.667629153721, 10.7677506481269), (106.667628614008, 10.7677503708842), (106.66744662399, 10.7676577214203), (106.667216888626, 10.7675408306262), (106.667161868227, 10.7675128359024), (106.667012119458, 10.7674366427911), (106.666659357657, 10.7672571553777), (106.666673753979, 10.7671954479766), (106.667048293768, 10.7672739882109), (106.667012119458, 10.7674366427911)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007bb9200 4. DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da98772 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 24. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 25. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 31. __tsan_thread_start_func @ 0x0000000007b08428 2025.04.02 09:43:08.499247 [ 5032 ] {29d0b5cd-29cb-4a4b-a5d0-dece5f50ba8d} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52424) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by 1, 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.501884 [ 5032 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.520388 [ 5032 ] {7c43fb06-0d60-4a27-9a0f-1a0b4452bc76} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52424) (comment: 02006_test_positional_arguments.sql) (in query: select max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 25. __tsan_thread_start_func @ 0x0000000007b08428 26. ? @ 0x00007fd7c201fac3 27. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.537572 [ 5032 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 7. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 18. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 19. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 25. __tsan_thread_start_func @ 0x0000000007b08428 26. ? @ 0x00007fd7c201fac3 27. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.551384 [ 5032 ] {8f3216ba-d855-4235-8965-74c43cb2df93} executeQuery: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52424) (comment: 02006_test_positional_arguments.sql) (in query: select 1 + max(x1), x2 from test group by -2, -1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:08.557621 [ 5032 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function max(x1) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000978e306 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14eb5 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000018b14e31 8. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000018b151f0 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000018b0fd74 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5735: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a94a29 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 20. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 21. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 27. __tsan_thread_start_func @ 0x0000000007b08428 28. ? @ 0x00007fd7c201fac3 29. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:11.633864 [ 5029 ] {2aaf9590-0ad6-4f10-ac6e-c3663d99faf6} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print extract_json('', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000007bca920 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bc9cc8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 2025.04.02 09:43:11.635757 [ 5029 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', ''), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000007bca920 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bc9cc8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 2025.04.02 09:43:11.655351 [ 5029 ] {365a098f-8208-4e9c-a7a0-7abc8c018ed7} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print extract_json('a', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000007bca920 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bc9cc8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 2025.04.02 09:43:11.660752 [ 5029 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT accurateCastOrNull(JSON_VALUE('', 'a'), 'String'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000007bca920 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bc9cc8 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b94964 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aabfc 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2218 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a1ce4 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a21b4 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3517: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abd13f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 30. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 31. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 2025.04.02 09:43:13.929531 [ 5034 ] {8fa4b6d5-c28a-4cb5-866c-872ccc0e2c27} executeQuery: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52434) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (in query: SELECT x FROM quorum3 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000088c0de0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5710: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000001b546be3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5789: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000001b547bc3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b547295 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c47c5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 9. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 10. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:14.008096 [ 5034 ] {} TCPHandler: Code: 289. DB::Exception: Replica doesn't have part '20181115_0_0_0' which was successfully written to quorum of other replicas. Send query to another replica or disable 'select_sequential_consistency' setting. (REPLICA_IS_NOT_IN_QUORUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000088c0de0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5710: DB::StorageReplicatedMergeTree::getMaxAddedBlocks() const @ 0x000000001b546be3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5789: DB::StorageReplicatedMergeTree::readLocalSequentialConsistencyImpl(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, unsigned long, unsigned long) @ 0x000000001b547bc3 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5741: DB::StorageReplicatedMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000001b547295 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:939: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c47c5 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 9. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 10. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:14.204801 [ 5029 ] {01f99ab3-84b9-4813-9153-2fda6351ec17} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print base64_encode_fromguid(dynamic(null));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000e73113c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72f05e 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 9. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000001acee609 10. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000001acee256 11. ./build_docker/./src/Columns/MaskOperations.cpp:297: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000001b1f6433 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000195a3fb5 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 19. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:14.272364 [ 5029 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION if(_CAST(1_UInt8, 'UInt8'_String) :: 1, toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)) :: 3, _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String) :: 4) -> if(_CAST(1_UInt8, 'UInt8'_String), toString(throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String)), _CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)) Nullable(String) : 5'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000e73113c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72f05e 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 8. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a525e 9. ./build_docker/./src/Columns/ColumnFunction.cpp:350: DB::ColumnFunction::reduce() const @ 0x000000001acee609 10. ./build_docker/./src/Columns/ColumnFunction.cpp:339: DB::ColumnFunction::reduce() const @ 0x000000001acee256 11. ./build_docker/./src/Columns/MaskOperations.cpp:297: DB::executeColumnIfNeeded(DB::ColumnWithTypeAndName&, bool) @ 0x000000001b1f6433 12. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000195a3fb5 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 19. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 28. __tsan_thread_start_func @ 0x0000000007b08428 29. ? @ 0x00007fd7c201fac3 30. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:14.512419 [ 5029 ] {a7c6c4cb-837b-4502-b415-0d47a80198bf} executeQuery: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print base64_encode_fromguid("abcd1231");), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000e73113c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72f05e 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 10. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:14.519478 [ 5029 ] {} TCPHandler: Code: 395. DB::Exception: Expected guid as argument: while executing 'FUNCTION throwIf(_CAST(true_Bool, 'Bool'_String) :: 1, 'Expected guid as argument'_String :: 2) -> throwIf(_CAST(true_Bool, 'Bool'_String), 'Expected guid as argument'_String) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::createRuntime(int, String const&) @ 0x000000000e73113c 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e72f05e 4. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 10. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 19. __tsan_thread_start_func @ 0x0000000007b08428 20. ? @ 0x00007fd7c201fac3 21. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:17.216930 [ 5029 ] {cb5b1275-acb2-4151-bcf8-59e0ecbcf977} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print parse_version(42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000171c0bfc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000171bee87 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000171be6de 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e565a4f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 2025.04.02 09:43:17.223933 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 's' to function 'splitByChar'. Expected: String, got: UInt8: In scope SELECT if((length(splitByChar('.', 42)) > 4) OR (length(splitByChar('.', 42)) < 1) OR (match(42, '.*[a-zA-Z]+.*') = 1), toDecimal128OrNull('NULL', 0), toDecimal128OrNull(substring(arrayStringConcat(arrayMap(x -> leftPad(x, 8, '0'), arrayMap(x -> if(empty(x), '0', x), arrayResize(splitByChar('.', 42), 4)))), 8), 0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x00000000171c0bfc 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000171bee87 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000171be6de 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e565a4f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 2025.04.02 09:43:18.193521 [ 5029 ] {ca256f63-6a77-403e-9a58-92007ed8ad53} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print parse_command_line(55, 'windows');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009bf69b0 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008423a04 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 2025.04.02 09:43:18.197805 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function empty: In scope SELECT if(empty(55) OR hasAll(splitByChar(' ', 55), ['']), arrayMap(x -> NULL, splitByChar(' ', '')), splitByChar(' ', 55)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::(anonymous namespace)::FunctionEmptyOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000009bf69b0 5. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008423a04 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 28. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 29. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 2025.04.02 09:43:18.958859 [ 5029 ] {442d407b-760c-4ed2-a858-434e045ac1f7} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52408) (comment: 02366_kql_func_string.sql) (in query: print parse_csv(65);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e26022d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:43:18.964240 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function position: In scope SELECT if(CAST(position(65, '\n'), 'UInt8'), splitByChar(',', substring(65, 1, position(65, '\n') - 1)), splitByChar(',', substring(65, 1, length(65)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e26022d 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007b95084 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a0dbb3a 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x00000000171a5df9 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x00000000171a58c2 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x00000000171a6465 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3494: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018abce77 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2879: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab788d 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2831: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018ab6ebc 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3817: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000018a9b5e7 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3975: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000018a9a378 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4299: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000018aceae5 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5563: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a93056 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 29. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 30. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 2025.04.02 09:43:20.227742 [ 5034 ] {c7408934-d2b5-4b5d-ba93-096ed4c1e8ce} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:52434) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (in query: INSERT INTO quorum1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1267: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001bfe3dfa 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1197: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001bfff9a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001bfe1776 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:491: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001bfce6e4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1232: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001bfe0352 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c8f2971 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001c8f2380 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c8f1d81 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001c521d95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001c53d30e 16. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001c41637a 17. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000001c409995 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:20.250682 [ 5034 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1267: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000001bfe3dfa 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1197: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000001bfff9a8 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000001bfe1776 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:491: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000001bfce6e4 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1232: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000001bfe0352 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c8f2971 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001c8f2380 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000001c8f1d81 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:164: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001c521d95 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000001c53d30e 16. ./build_docker/./src/Server/TCPHandler.cpp:1122: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000001c41637a 17. ./build_docker/./src/Server/TCPHandler.cpp:665: DB::TCPHandler::runImpl() @ 0x000000001c409995 18. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:35.749635 [ 5167 ] {43561930-a0ba-47fd-8031-e7f4193def02} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48876) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets ((fact_1_id), (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5416: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a95823 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:35.760187 [ 5167 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5416: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a95823 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:35.871771 [ 5167 ] {7befb622-c661-4b25-9c30-b8150a598717} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:48876) (comment: 01883_with_grouping_sets.sql) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets (fact_1_id, (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5416: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a95823 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:35.876110 [ 5167 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5416: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000018a95823 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:172: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000018a91e87 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000018a912e5 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000019512327 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000019994ce7 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:167: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000019992280 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000019996a50 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001991076b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1305: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20b76 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 14. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 15. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 21. __tsan_thread_start_func @ 0x0000000007b08428 22. ? @ 0x00007fd7c201fac3 23. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.634841 [ 5198 ] {53193d79-442b-4e18-94cf-a5982ace6d36} executeQuery: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35850) (comment: 01263_type_conversion_nvartolomei.sql) (in query: SELECT toString(v) FROM (SELECT v FROM d ORDER BY v) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000175e0c7c 6. ./src/Functions/FunctionsConversion.h:2456: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001748d79e 7. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001748cce0 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.645841 [ 5202 ] {b8b92ef0-2055-4c87-9398-fdecc1218055} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35892) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.682750 [ 5202 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary' :: 3, tuple(materialize('Ke\0')) :: 10) -> dictHas('test_dictionary', tuple(materialize('Ke\0'))) UInt8 : 5'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.689668 [ 5198 ] {} TCPHandler: Code: 691. DB::Exception: Unexpected value 2 in enum: while executing 'FUNCTION toString(__table1.v :: 0) -> toString(__table1.v) String : 1'. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x00000000096b8446 5. ./src/DataTypes/EnumValues.h:54: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000175e0c7c 6. ./src/Functions/FunctionsConversion.h:2456: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001748d79e 7. ./src/Functions/FunctionsConversion.h:2292: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001748cce0 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001c5218cc 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:127: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001c5215aa 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001c53769b 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.793827 [ 5202 ] {26765a00-9808-42b2-b59e-89892ffc14a2} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35892) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:36.797291 [ 5202 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary' :: 0, materialize('a') :: 3) -> dictHas('non_existing_dictionary', materialize('a')) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:37.011129 [ 5202 ] {726845dc-70c2-42a8-af90-3dd7f595d49d} executeQuery: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35892) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas(NULL, (dictHas(NULL, (('', materialize(NULL)), materialize(NULL))), 'KeyKey')), dictHas('test_dictionary', tuple(materialize('Ke\0'))), tuple(dictHas(NULL, (tuple('Ke\0Ke\0Ke\0Ke\0Ke\0Ke\0\0\0\0Ke\0'), materialize(NULL)))), 'test_dicti\0nary', (('', materialize(NULL)), dictHas(NULL, (dictHas(NULL, tuple(materialize(NULL))), 'KeyKeyKeyKeyKeyKeyKeyKey')), materialize(NULL));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:37.017710 [ 5202 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_dictionary`) not found: while executing 'FUNCTION dictHas('test_dictionary'_String :: 0, tuple(materialize('Ke\0'_String)) :: 1) -> dictHas('test_dictionary'_String, tuple(materialize('Ke\0'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:37.110830 [ 5202 ] {5a05ebbf-5ae0-4ae1-9864-87bef630c99f} executeQuery: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:35892) (comment: 02516_projections_and_context.sql) (in query: SELECT count() FROM test1__fuzz_37 GROUP BY dictHas('non_existing_dictionary', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:37.115334 [ 5202 ] {} TCPHandler: Code: 36. DB::Exception: Dictionary (`non_existing_dictionary`) not found: while executing 'FUNCTION dictHas('non_existing_dictionary'_String :: 0, materialize('a'_String) :: 3) -> dictHas('non_existing_dictionary'_String, materialize('a'_String)) UInt8 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:168: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000194514a0 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:84: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x0000000019451054 6. DB::FunctionDictHelper::getDictionary(String const&) @ 0x0000000007d93586 7. DB::FunctionDictHas::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007da2feb 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000171aab5c 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a223c 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a2e35 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000171a4b4f 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000018f2ee65 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001c8f31d1 14. ./src/Processors/ISimpleTransform.h:32: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000013865097 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001c50aec5 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:49: DB::ExecutionThreadContext::executeTask() @ 0x000000001c532a47 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:290: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001c52254c 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:256: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001c5236f3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104f2db2 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104fa886 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000104fa7a2 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000104ef7ee 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x00000000104f79dc 24. __tsan_thread_start_func @ 0x0000000007b08428 25. ? @ 0x00007fd7c201fac3 26. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.002329 [ 4498 ] {92757012-f148-4443-8650-55bbd3fe2270} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.004589 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.046277 [ 4498 ] {1fcd3db2-5e31-4615-ab44-37709aa64d1b} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t != B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.054033 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t != B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.060291 [ 1434 ] {0a269ea3-13d5-4a36-a8d9-e1141e283a90} executeQuery: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36054) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001bc1304c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3887: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001bb8e0f8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a576d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.066762 [ 1434 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001bc1304c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3887: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001bb8e0f8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a576d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.243165 [ 4498 ] {72d34d5d-a990-419d-b73c-1247b02333af} executeQuery: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.247008 [ 4498 ] {} TCPHandler: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.726476 [ 1434 ] {93f77dd9-6097-4dd7-8957-bd5629957805} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36054) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001bc1304c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3887: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001bb8e0f8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a576d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:40.731106 [ 1434 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001bc1304c 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3887: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001bb8e0f8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:218: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a576d 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 9. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 10. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 16. __tsan_thread_start_func @ 0x0000000007b08428 17. ? @ 0x00007fd7c201fac3 18. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.119487 [ 4498 ] {877e049a-c9c1-4e7b-8ce3-1687b46c0b7e} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.121317 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.146916 [ 4498 ] {114b1d67-3397-4ea0-afe3-ebc6ed6ea282} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t != B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.149140 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t != B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.187719 [ 4498 ] {55b17117-57fb-4f72-88a7-a345b864528b} executeQuery: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.193248 [ 4498 ] {} TCPHandler: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.833392 [ 4498 ] {f4e725c0-d916-4ed4-ba21-2fac311be11f} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:41.834788 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:42.016909 [ 4498 ] {2c28855b-bd2e-4610-b20c-c8a6f7d58d10} executeQuery: Code: 403. DB::Exception: INNER JOIN ON expression A.t != B.t contains column from left and right table, which is not supported with `join_use_nulls`. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000010806dc6 4. ./build_docker/./src/Planner/PlannerJoins.cpp:379: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f35db 5. ./build_docker/./src/Planner/PlannerJoins.cpp:230: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f2b8d 6. ./build_docker/./src/Planner/PlannerJoins.cpp:484: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000199eb2ad 7. ./build_docker/./src/Planner/PlannerJoins.cpp:673: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000199ea442 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1369: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cb43f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 10. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 11. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:42.027434 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: INNER JOIN ON expression A.t != B.t contains column from left and right table, which is not supported with `join_use_nulls`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000010806dc6 4. ./build_docker/./src/Planner/PlannerJoins.cpp:379: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f35db 5. ./build_docker/./src/Planner/PlannerJoins.cpp:230: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f2b8d 6. ./build_docker/./src/Planner/PlannerJoins.cpp:484: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000199eb2ad 7. ./build_docker/./src/Planner/PlannerJoins.cpp:673: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000199ea442 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1369: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cb43f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 10. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 11. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:42.295966 [ 4498 ] {65455b09-27d2-4924-9a3d-2930860c9347} executeQuery: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:42.305656 [ 4498 ] {} TCPHandler: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.048083 [ 4498 ] {78ac0ae4-b313-4719-978b-8337cd2dc062} executeQuery: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.051561 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: JOIN ASOF INNER JOIN ... ON (A.a = B.b) AND (A.t = B.t) no inequality in ASOF JOIN ON section. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1595: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cfef9 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.073695 [ 4498 ] {3e415398-6f44-4a6d-914d-96eb6641465d} executeQuery: Code: 403. DB::Exception: INNER JOIN ON expression A.t != B.t contains column from left and right table, which is not supported with `join_use_nulls`. (INVALID_JOIN_ON_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000010806dc6 4. ./build_docker/./src/Planner/PlannerJoins.cpp:379: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f35db 5. ./build_docker/./src/Planner/PlannerJoins.cpp:230: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f2b8d 6. ./build_docker/./src/Planner/PlannerJoins.cpp:484: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000199eb2ad 7. ./build_docker/./src/Planner/PlannerJoins.cpp:673: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000199ea442 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1369: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cb43f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 10. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 11. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.076982 [ 4498 ] {} TCPHandler: Code: 403. DB::Exception: INNER JOIN ON expression A.t != B.t contains column from left and right table, which is not supported with `join_use_nulls`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. ./src/Common/Exception.h:123: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x0000000010806dc6 4. ./build_docker/./src/Planner/PlannerJoins.cpp:379: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f35db 5. ./build_docker/./src/Planner/PlannerJoins.cpp:230: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000199f2b8d 6. ./build_docker/./src/Planner/PlannerJoins.cpp:484: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000199eb2ad 7. ./build_docker/./src/Planner/PlannerJoins.cpp:673: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000199ea442 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1369: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199cb43f 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 10. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 11. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 15. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 16. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 22. __tsan_thread_start_func @ 0x0000000007b08428 23. ? @ 0x00007fd7c201fac3 24. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.100923 [ 4498 ] {1d87b4e8-4e4b-4398-b0c7-e5444c40558f} executeQuery: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:36034) (comment: 00976_asof_join_on.gen.sql) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:43.104955 [ 4498 ] {} TCPHandler: Code: 48. DB::Exception: ASOF join doesn't support JOIN ON expression ASOF INNER JOIN ... ON ((A.a = B.b) AND (A.t < B.t)) OR (A.a = (B.b + 1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1520: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x00000000199d02d1 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2091: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bcb21 6. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 7. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 11. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 12. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 18. __tsan_thread_start_func @ 0x0000000007b08428 19. ? @ 0x00007fd7c201fac3 20. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:48.283754 [ 4905 ] {11b0bb57-b585-411b-acb1-a29b16955205} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41398) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:48.291847 [ 4905 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:48.444249 [ 4906 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41406, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000105c2fff 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000105c3674 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c283c0f 6. DB::ReadBuffer::next() @ 0x0000000007ce3a5b 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000001c408df6 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:43:48.445335 [ 4906 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41406, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000105c2fff 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000105c3674 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c283c0f 6. DB::ReadBuffer::next() @ 0x0000000007ce3a5b 7. ./src/IO/ReadBuffer.h:103: DB::TCPHandler::runImpl() @ 0x000000001c408df6 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:43:49.044071 [ 4858 ] {58c5ffa2-0996-4cfc-b254-4e436d5fd433} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41420) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:49.051579 [ 4858 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:49.152510 [ 4861 ] {80f34a2f-f85d-4b71-b713-31b2521e3847} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41432). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:43:49.154323 [ 4861 ] {80f34a2f-f85d-4b71-b713-31b2521e3847} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41432). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41432) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_e9rkp3xh`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) AND (`__table1`.`b` = 0)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:49.155959 [ 4861 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41432). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:50.371973 [ 4902 ] {3d4956bb-aabe-454a-b723-828c286cbc58} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41484) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:50.374308 [ 4902 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:50.514101 [ 4866 ] {c56ac7e1-0feb-47d6-9620-307c9ca68a49} executeQuery: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41492) (comment: 02018_multiple_with_fill_for_the_same_column.sql) (in query: SELECT x, y FROM (SELECT 5 AS x, 'Hello' AS y) ORDER BY x WITH FILL FROM 3 TO 7, y, x WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:282: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb6745f 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:50.515816 [ 4866 ] {} TCPHandler: Code: 475. DB::Exception: Multiple WITH FILL for identical expressions is not supported in ORDER BY. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:282: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000001cb6745f 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000001cb617ee 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001837aeef 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:631: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001837ac1d 8. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000001839752d 9. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb60733 10. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001cb80e31 11. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001cbb2cb9 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x00000000199963b7 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:228: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000019996010 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 16. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 17. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 23. __tsan_thread_start_func @ 0x0000000007b08428 24. ? @ 0x00007fd7c201fac3 25. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.322892 [ 4944 ] {3759c442-6ee0-479d-850d-7049fe28c910} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41506) (comment: 01320_optimize_skip_unused_shards_no_non_deterministic.sql) (in query: select * from dist_01320 where key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1548: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001b2bc242 5. ./build_docker/./src/Storages/StorageDistributed.cpp:448: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001b2ba96d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:914: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c453a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.324779 [ 4944 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000007ba59ba 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1548: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000001b2bc242 5. ./build_docker/./src/Storages/StorageDistributed.cpp:448: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000001b2ba96d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:914: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000199c453a 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2035: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x00000000199bc5e2 8. ./build_docker/./src/Planner/Planner.cpp:1561: DB::Planner::buildPlanForQueryNode() @ 0x000000001999e256 9. ./build_docker/./src/Planner/Planner.cpp:1315: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001999938a 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:241: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x00000000199965db 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1317: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e20d7a 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.568515 [ 4947 ] {6563dc4b-b0eb-4a97-8053-3ed804f2236b} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.570453 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.726867 [ 4947 ] {7f29f248-5450-4ec7-84a9-f39cc15d4c72} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree ORDER BY (key, value) SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.729464 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.742169 [ 4947 ] {3378dc74-6f01-4ade-8385-eb557e71c152} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.743606 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.757760 [ 4947 ] {31c443fa-ab11-45e0-a8a0-f18e899da73a} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.759991 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.773502 [ 4947 ] {cf2e464b-09f8-4c7c-9417-158c7e37dfe7} executeQuery: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` AggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.775184 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column `value` with type AggregateFunction(sum, UInt64) is not allowed in key expression, it's not comparable. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007b97ae6 4. ./build_docker/./src/Storages/KeyDescription.cpp:173: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000001b26dc09 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:654: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c661 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.788918 [ 4947 ] {e9adf565-e3f9-48c7-9d79-8c2ab736bb4b} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: CREATE TABLE data (`key` Int, `value` SimpleAggregateFunction(sum, UInt64)) ENGINE = AggregatingMergeTree PRIMARY KEY value ORDER BY (value, key) SETTINGS index_granularity = 10656, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.39076995849609375, replace_long_file_name_to_hash = false, max_file_name_length = 4, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 109018234, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 10962470, merge_max_block_size = 215, old_parts_lifetime = 44., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 37, min_merge_bytes_to_use_direct_io = 7053533844, index_granularity_bytes = 17583853, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18760, primary_key_compress_block_size = 13823, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:51.790586 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:657: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001c02c701 6. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x0000000017a20ae4 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b2ef653 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1933: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000194d5239 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1749: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000194ccd70 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2324: DB::InterpreterCreateQuery::execute() @ 0x00000000194dc31b 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 13. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 14. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 20. __tsan_thread_start_func @ 0x0000000007b08428 21. ? @ 0x00007fd7c201fac3 22. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:52.655967 [ 4947 ] {262a9a93-ef2e-4f49-ae23-518cc395f773} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: alter table data add column value SimpleAggregateFunction(sum, UInt64), modify order by (key, value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:380: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001c0395c4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a57b1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:52.657817 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:380: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001c0395c4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a57b1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:53.079034 [ 4947 ] {f2f911c1-5d4c-4931-ab52-756c3023f2a9} executeQuery: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41510) (comment: 03020_order_by_SimpleAggregateFunction.sql) (in query: alter table data_rep add column value SimpleAggregateFunction(sum, UInt64), modify order by (key, value);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6386: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001b552af1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a57b1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:53.080887 [ 4947 ] {} TCPHandler: Code: 549. DB::Exception: Column with type SimpleAggregateFunction(sum, UInt64) is not allowed in key expression. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000007b95ade 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007b95460 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9205: DB::MergeTreeData::verifySortingKey(DB::KeyDescription const&) @ 0x000000001bbff247 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6386: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000001b552af1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:219: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000194a57b1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:80: DB::InterpreterAlterQuery::execute() @ 0x00000000194a2f43 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1368: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000019e216b9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1535: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000019e1c6d6 10. ./build_docker/./src/Server/TCPHandler.cpp:656: DB::TCPHandler::runImpl() @ 0x000000001c409825 11. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 17. __tsan_thread_start_func @ 0x0000000007b08428 18. ? @ 0x00007fd7c201fac3 19. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:54.468595 [ 2683 ] {} BaseDaemon: This ClickHouse version is not official and should be upgraded to the official build. 2025.04.02 09:43:54.470745 [ 2683 ] {} BaseDaemon: Changed settings: min_compress_block_size = 1147731, max_compress_block_size = 2885936, max_block_size = 62186, min_external_table_block_size_bytes = 0, max_joined_block_size_rows = 98860, max_insert_threads = 2, max_threads = 1, max_read_buffer_size = 995864, connect_timeout_with_failover_ms = 2000, connect_timeout_with_failover_secure_ms = 3000, idle_connection_timeout = 36000, s3_max_get_rps = 1000000, s3_max_get_burst = 2000000, s3_max_put_rps = 1000000, s3_max_put_burst = 2000000, s3_check_objects_after_upload = true, use_uncompressed_cache = true, max_remote_read_network_bandwidth = 1000000000000, max_remote_write_network_bandwidth = 1000000000000, max_local_read_bandwidth = 1000000000000, max_local_write_bandwidth = 1000000000000, stream_like_engine_allow_direct_select = true, enable_multiple_prewhere_read_steps = false, replication_wait_for_inactive_replica_timeout = 30, min_count_to_compile_expression = 0, compile_aggregate_expressions = false, min_count_to_compile_aggregate_expression = 0, group_by_two_level_threshold = 881876, group_by_two_level_threshold_bytes = 13928924, enable_memory_bound_merging_of_aggregation_results = false, allow_nonconst_timezone_arguments = true, parallel_distributed_insert_select = 1, input_format_parallel_parsing = false, min_chunk_bytes_for_parallel_parsing = 17686868, merge_tree_coarse_index_granularity = 26, min_bytes_to_use_direct_io = 10737418240, min_bytes_to_use_mmap_io = 1, log_queries = true, insert_quorum_timeout = 60000, merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.5199999809265137, http_wait_end_of_query = true, http_response_buffer_size = 3622091, fsync_metadata = false, http_send_timeout = 60., http_receive_timeout = 60., use_index_for_in_with_subqueries_max_values = 1000000000, opentelemetry_start_trace_probability = 0.10000000149011612, max_rows_to_read = 20000000, max_bytes_to_read = 1000000000000, max_bytes_to_read_leaf = 1000000000000, max_rows_to_group_by = 10000000000, max_bytes_before_external_group_by = 10737418240, max_rows_to_sort = 10000000000, max_bytes_to_sort = 10000000000, prefer_external_sort_block_bytes = 0, max_bytes_before_external_sort = 10737418240, max_bytes_before_remerge_sort = 1309929691, max_result_rows = 1000000000, max_result_bytes = 1000000000, max_execution_time = 600., max_execution_time_leaf = 600., max_execution_speed = 100000000000, max_execution_speed_bytes = 10000000000000, timeout_before_checking_execution_speed = 300., max_estimated_execution_time = 600., max_columns_to_read = 20000, max_temporary_columns = 20000, max_temporary_non_const_columns = 20000, max_rows_in_set = 10000000000, max_bytes_in_set = 10000000000, max_rows_in_join = 10000000000, max_bytes_in_join = 10000000000, cross_join_min_rows_to_compress = 1, cross_join_min_bytes_to_compress = 0, max_rows_to_transfer = 1000000000, max_bytes_to_transfer = 1000000000, max_rows_in_distinct = 10000000000, max_bytes_in_distinct = 10000000000, max_memory_usage = 5000000000, max_memory_usage_for_user = 32000000000, max_untracked_memory = 1048576, memory_profiler_step = 1048576, max_network_bandwidth = 100000000000, max_network_bytes = 1000000000000, max_network_bandwidth_for_user = 100000000000, max_network_bandwidth_for_all_users = 100000000000, max_temporary_data_on_disk_size_for_user = 100000000000, max_temporary_data_on_disk_size_for_query = 100000000000, max_backup_bandwidth = 100000000000, log_comment = '01099_parallel_distributed_insert_select.sql', send_logs_level = 'error', prefer_localhost_replica = false, aggregation_in_order_max_block_bytes = 42302895, read_in_order_two_level_merge_threshold = 83, max_hyperscan_regexp_length = 1000000, max_hyperscan_regexp_total_length = 10000000, allow_introspection_functions = true, database_atomic_wait_for_drop_and_detach_synchronously = true, optimize_if_chain_to_multiif = true, optimize_if_transform_strings_to_enum = true, optimize_append_index = true, query_cache_max_size_in_bytes = 10000000, query_cache_max_entries = 100000, distributed_ddl_entry_format_version = 6, external_storage_max_read_rows = 10000000000, external_storage_max_read_bytes = 10000000000, remote_filesystem_read_method = 'read', merge_tree_min_bytes_per_task_for_remote_reading = 16777216, merge_tree_compact_parts_min_granules_to_multibuffer_read = 101, async_insert_busy_timeout_max_ms = 5000, enable_filesystem_cache = true, enable_filesystem_cache_on_write_operations = true, throw_on_error_from_cache_on_write_operations = true, filesystem_cache_segments_batch_size = 3, use_page_cache_for_disks_without_file_cache = true, page_cache_inject_eviction = true, load_marks_asynchronously = true, allow_prefetched_read_pool_for_remote_filesystem = true, allow_prefetched_read_pool_for_local_filesystem = false, filesystem_prefetch_step_marks = 50, filesystem_prefetch_max_memory_usage = 67108864, filesystem_prefetches_limit = 10, max_streams_for_merge_tree_reading = 1000, optimize_sorting_by_input_stream_properties = false, insert_keeper_max_retries = 100, insert_keeper_retry_initial_backoff_ms = 1, insert_keeper_retry_max_backoff_ms = 10, insert_keeper_fault_injection_probability = 0.009999999776482582, optimize_distinct_in_order = false, allow_experimental_parallel_reading_from_replicas = 0, session_timezone = 'Asia/Anadyr', output_format_native_write_json_as_string = true 2025.04.02 09:43:55.330467 [ 4990 ] {3d30a536-1df0-4bc3-953e-b3e8bf67b340} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37912) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b <= 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:55.343851 [ 4990 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:55.990354 [ 5022 ] {3414fa2b-4da8-4bb3-89b4-64fdb14b3883} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37948) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 WHERE c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:55.995223 [ 5022 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:56.076924 [ 4898 ] {bd877237-f1e4-4663-b304-c3dadc94896f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41464). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:41464) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_e9rkp3xh`.`mergetree_00754` AS `__table1` PREWHERE `__table1`.`a` = 0 WHERE `__table1`.`c` LIKE '%l%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:1416: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c417172 7. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:56.079921 [ 4898 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41464). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:1416: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c417172 7. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:56.641236 [ 5020 ] {c99b60f7-79e8-444f-aade-cfc5d596338e} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37968) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 OR a = 1 AND b = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:56.645658 [ 5020 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:56.670919 [ 5024 ] {d8dc14d2-8773-4c77-88f3-20d55a1fe724} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37970). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:43:56.673272 [ 5024 ] {d8dc14d2-8773-4c77-88f3-20d55a1fe724} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37970). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37970) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_e9rkp3xh`.`mergetree_00754` AS `__table1` PREWHERE (`__table1`.`a` = 0) OR ((`__table1`.`a` = 1) AND (`__table1`.`b` = 0))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:56.675088 [ 5024 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:37970). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:57.332409 [ 5033 ] {170965d0-a8c4-43b1-b943-22c7dc508ee6} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:37988) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR a = 2 AND b = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:57.343131 [ 5033 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:57.381478 [ 5031 ] {d37d426d-0344-4a3f-8d96-be9f704baa0f} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38010). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 (version 24.12.2.20221.altinityantalya (altinity build)) 2025.04.02 09:43:57.384709 [ 5031 ] {d37d426d-0344-4a3f-8d96-be9f704baa0f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38010). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:38010) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_e9rkp3xh`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR ((`__table1`.`a` = 2) AND (`__table1`.`b` = 2))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:57.389601 [ 5031 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38010). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:2464: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000001c422003 7. ./build_docker/./src/Server/TCPHandler.cpp:1260: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c416ef7 8. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 9. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 15. __tsan_thread_start_func @ 0x0000000007b08428 16. ? @ 0x00007fd7c201fac3 17. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:58.056446 [ 4984 ] {24edc57c-107e-42ff-bf96-9871bb39365e} executeQuery: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:38030) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count(*) FROM distributed_00754 PREWHERE a = 0 AND b = 0 OR c LIKE '%l%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:58.062621 [ 4984 ] {} TCPHandler: Code: 279. DB::Exception: All connection tries failed. Log: Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) Code: 210. DB::NetException: Connection refused (localhost:1). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) : While executing Remote. (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x000000001b717959 3. ./build_docker/./src/Client/HedgedConnectionsFactory.cpp:125: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000001c2bae07 4. ./build_docker/./src/Client/HedgedConnections.cpp:63: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000001c2ad8d8 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x00000000183c6784 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:226: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x00000000183bdda2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000183b2df3 8. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:39: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000183e00cb 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x00000000183df19f 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x00000000183deca0 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000183dd7e3 2025.04.02 09:43:58.075489 [ 5036 ] {c0eca41e-5ab9-4668-bf98-0c9979eecd13} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38042). (NETWORK_ERROR) (version 24.12.2.20221.altinityantalya (altinity build)) (from [::1]:38042) (comment: 00754_distributed_optimize_skip_select_on_unused_shards_with_prewhere.sh) (in query: SELECT count() AS `count()` FROM `test_e9rkp3xh`.`mergetree_00754` AS `__table1` PREWHERE ((`__table1`.`a` = 0) AND (`__table1`.`b` = 0)) OR (`__table1`.`c` LIKE '%l%')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:1416: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c417172 7. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:58.078268 [ 5036 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:38042). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000020b03283 1. ./build_docker/./src/Common/Exception.cpp:105: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000103dda74 2. ./src/Common/Exception.h:105: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000105c3eef 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000105c5aaf 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001c28772e 5. DB::WriteBuffer::next() @ 0x0000000007ba6abc 6. ./build_docker/./src/Server/TCPHandler.cpp:1416: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000001c417172 7. ./build_docker/./src/Server/TCPHandler.cpp:670: DB::TCPHandler::runImpl() @ 0x000000001c4099c2 8. ./build_docker/./src/Server/TCPHandler.cpp:2603: DB::TCPHandler::run() @ 0x000000001c428288 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x0000000020c0fe43 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x0000000020c106b2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000020b89483 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000020b87730 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000020b85c0a 14. __tsan_thread_start_func @ 0x0000000007b08428 15. ? @ 0x00007fd7c201fac3 16. ? @ 0x00007fd7c20b1850 2025.04.02 09:43:58.819850 [ 430 ] {} Application: Child process was terminated by signal 6.